2025.06.12 18:51:30.096280 [ 420 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.12 18:51:30.096421 [ 420 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.06.12 18:51:30.215882 [ 420 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.06.12 18:51:30.217287 [ 420 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.06.12 18:51:32.252455 [ 420 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.06.12 18:51:32.253635 [ 420 ] {} KeeperLogStore: Removing all changelogs 2025.06.12 18:51:32.254736 [ 420 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.12 18:51:32.263213 [ 420 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.12 18:51:32.263258 [ 420 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.12 18:51:32.314402 [ 1013 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.12 18:51:32.498916 [ 420 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.06.12 18:51:32.498971 [ 420 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.06.12 18:51:32.830144 [ 420 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.06.12 18:51:41.881723 [ 424 ] {023af8be-9a98-4781-b757-e91872f8d428} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.06.12 18:51:52.765362 [ 424 ] {71de9756-0cb7-4b78-8e07-c961d9d14e84} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.06.12 18:52:00.447788 [ 1027 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.06.12 18:52:01.654917 [ 1281 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.12 18:52:01.655035 [ 1281 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.06.12 18:52:01.694091 [ 1281 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.06.12 18:52:01.695208 [ 1281 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.06.12 18:52:03.541092 [ 1281 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.12 18:52:03.551083 [ 1281 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.12 18:52:03.551152 [ 1281 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.12 18:52:03.602437 [ 1874 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.12 18:52:05.670381 [ 1281 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.06.12 18:52:40.972202 [ 1907 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_1_5_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f959f6d6ac3 19. ? @ 0x00007f959f768850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:53:35.526607 [ 1285 ] {79eb3d45-9d45-41b7-bc8e-dc9d70379ce6} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.451895887 seconds, maximum: 60: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TIMEOUT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56342) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfd406 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfc526 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb32d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f959f6d6ac3 16. ? @ 0x00007f959f768850 2025.06.12 18:53:41.613151 [ 1285 ] {79eb3d45-9d45-41b7-bc8e-dc9d70379ce6} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.451895887 seconds, maximum: 60: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfd406 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfc526 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb32d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f959f6d6ac3 16. ? @ 0x00007f959f768850 2025.06.12 18:54:18.839289 [ 1896 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.06.12 18:54:18.839599 [ 1896 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.06.12 18:54:30.476435 [ 1285 ] {c316680b-067e-4e44-b04a-bfe9b94c7801} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 7372672 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46658) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 8. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9bd41a 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000007622af1 10. ./build_docker/./src/Columns/ColumnFixedString.cpp:369: COW::immutable_ptr DB::ColumnFixedString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000018c6af36 11. ./build_docker/./src/Columns/ColumnFixedString.cpp:344: DB::ColumnFixedString::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000018c4ab4d 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000019acc046 13. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:368: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000019c804bf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd0446 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 17. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f959f6d6ac3 31. ? @ 0x00007f959f768850 2025.06.12 18:54:36.245526 [ 1285 ] {c316680b-067e-4e44-b04a-bfe9b94c7801} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 7372672 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 8. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9bd41a 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000007622af1 10. ./build_docker/./src/Columns/ColumnFixedString.cpp:369: COW::immutable_ptr DB::ColumnFixedString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000018c6af36 11. ./build_docker/./src/Columns/ColumnFixedString.cpp:344: DB::ColumnFixedString::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000018c4ab4d 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000019acc046 13. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:368: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000019c804bf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd0446 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 17. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f959f6d6ac3 31. ? @ 0x00007f959f768850 2025.06.12 18:54:45.115671 [ 1906 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {14a4948f-ad6d-4f55-847a-9babfee874f5::202506_1_26_5}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f959f6d6ac3 19. ? @ 0x00007f959f768850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:55:03.848246 [ 1896 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.06.12 18:55:18.850551 [ 1896 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.06.12 18:55:47.546607 [ 1285 ] {e91e98c5-7c4e-4824-bd5b-af382986d3d3} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1050750 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41710) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 9. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9bd41a 10. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000fa95ba6 11. ./src/IO/BufferWithOwnMemory.h:80: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x0000000016d5e830 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:89: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000019abe1bf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if>::__unique_single std::make_unique[abi:v15007], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings const&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings const&) @ 0x0000000019ad5eeb 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:180: void std::__function::__policy_invoker::__call_impl::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019ad27e6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016f5c727 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000019acaa67 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019aca7fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019aac052 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:183: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019abcfe4 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&) @ 0x0000000019c7ff6b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd02d8 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 26. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 2025.06.12 18:55:51.621117 [ 1285 ] {e91e98c5-7c4e-4824-bd5b-af382986d3d3} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1050750 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 9. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9bd41a 10. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000fa95ba6 11. ./src/IO/BufferWithOwnMemory.h:80: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x0000000016d5e830 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:89: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000019abe1bf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if>::__unique_single std::make_unique[abi:v15007], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings const&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings const&) @ 0x0000000019ad5eeb 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:180: void std::__function::__policy_invoker::__call_impl::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019ad27e6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016f5c727 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000019acaa67 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019aca7fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019aac052 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:183: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019abcfe4 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&) @ 0x0000000019c7ff6b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd02d8 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 26. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 2025.06.12 18:55:57.292158 [ 1889 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.06.12 18:55:59.637880 [ 2652 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.12 18:55:59.638006 [ 2652 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.06.12 18:55:59.677256 [ 2652 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.06.12 18:55:59.678780 [ 2652 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.06.12 18:55:59.679935 [ 2652 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.06.12 18:56:01.468467 [ 2652 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.12 18:56:01.478121 [ 2652 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.12 18:56:01.478204 [ 2652 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.12 18:56:01.529392 [ 3245 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.12 18:56:03.714076 [ 2652 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.06.12 18:56:04.904406 [ 2656 ] {527c197d-2ac3-419e-a470-3bac11d5685c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39316) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:04.905296 [ 2656 ] {527c197d-2ac3-419e-a470-3bac11d5685c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:10.135719 [ 2656 ] {808e2fa0-d185-410c-ae11-db462589191f} 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.10057.altinitytest (altinity build)) (from [::1]:39330) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:10.136489 [ 2656 ] {808e2fa0-d185-410c-ae11-db462589191f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:22.799805 [ 2658 ] {594a0182-cfaa-43fe-b6cd-3684cc675e8b} 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.10057.altinitytest (altinity build)) (from [::1]:53966) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:22.800911 [ 2658 ] {594a0182-cfaa-43fe-b6cd-3684cc675e8b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:23.175397 [ 2658 ] {2dcb8999-7657-4196-8a24-22b5ac8f01bc} 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.10057.altinitytest (altinity build)) (from [::1]:53976) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:23.176962 [ 2658 ] {2dcb8999-7657-4196-8a24-22b5ac8f01bc} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:25.239717 [ 3528 ] {77b1474c-0979-40d7-bc4f-938e3e27d6e3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54268) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:25.241152 [ 3528 ] {77b1474c-0979-40d7-bc4f-938e3e27d6e3} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:25.660048 [ 2658 ] {32a101d2-7542-4185-ae3f-17eb7500e883} 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.10057.altinitytest (altinity build)) (from [::1]:54286) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:25.660935 [ 2658 ] {32a101d2-7542-4185-ae3f-17eb7500e883} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:25.722270 [ 2656 ] {84fcb001-60e4-48de-9246-b759ee91d9be} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42916) (comment: 00079_array_join_not_used_joined_column.sql) (in query: SELECT PP.Key1 AS `ym:s:paramsLevel1`, sum(arrayAll(`x_1` -> `x_1`= '', ParsedParams.Key2)) AS `ym:s:visits` FROM test.hits ARRAY JOIN ParsedParams AS `PP` WHERE CounterID = 1704509 GROUP BY `ym:s:paramsLevel1` ORDER BY PP.Key1, `ym:s:visits` LIMIT 0, 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:25.763247 [ 2656 ] {84fcb001-60e4-48de-9246-b759ee91d9be} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:26.325619 [ 2658 ] {4f42c2a6-8437-4711-9bb9-fca7cecf380f} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49060) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305a(x Int8) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Access/ContextAccess.cpp: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 @ 0x00000000167265d6 5. ./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 @ 0x0000000016724dbd 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000001671f9ab 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x00000000166f95ff 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x00000000175a3477 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50c28 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:26.412467 [ 2658 ] {4f42c2a6-8437-4711-9bb9-fca7cecf380f} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Access/ContextAccess.cpp: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 @ 0x00000000167265d6 5. ./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 @ 0x0000000016724dbd 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000001671f9ab 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x00000000166f95ff 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x00000000175a3477 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50c28 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:26.511707 [ 2658 ] {} DynamicQueryHandler: Code: 164. DB::Exception: Cannot modify 'readonly' setting 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000015e5ccbe 3. ./build_docker/./src/Access/SettingsConstraints.cpp:307: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016825fa4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 5. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 7. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a12ed11 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:26.713171 [ 2658 ] {8df4c2c6-e761-4135-a7f4-3dd672f93cce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49084) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305a(x Int8) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a5056b1 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a503fc5 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000001a506a03 10. ./src/Processors/Formats/IOutputFormat.h:123: DB::IOutputFormat::work() @ 0x000000001a3019c5 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:26.714978 [ 2658 ] {8df4c2c6-e761-4135-a7f4-3dd672f93cce} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a5056b1 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a503fc5 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000001a506a03 10. ./src/Processors/Formats/IOutputFormat.h:123: DB::IOutputFormat::work() @ 0x000000001a3019c5 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:26.739358 [ 3550 ] {0c5774ff-3e56-463b-b184-eb58f16a0a42} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54410) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:26.740502 [ 3550 ] {0c5774ff-3e56-463b-b184-eb58f16a0a42} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:26.948576 [ 2658 ] {549e8f85-a8a9-4a00-8691-97100b4866a4} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49102) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305c(x Int8) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Access/ContextAccess.cpp: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 @ 0x00000000167265d6 5. ./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 @ 0x0000000016724dbd 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000001671f9ab 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x00000000166f95ff 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x00000000175a3477 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50c28 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:26.949424 [ 2658 ] {549e8f85-a8a9-4a00-8691-97100b4866a4} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Access/ContextAccess.cpp: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 @ 0x00000000167265d6 5. ./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 @ 0x0000000016724dbd 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000001671f9ab 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x00000000166f95ff 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x00000000175a3477 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50c28 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:26.961092 [ 2658 ] {c09af9da-8b1b-46fc-8a71-f4e51a34a716} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49104) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305c(x Int8) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Access/ContextAccess.cpp: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 @ 0x00000000167265d6 5. ./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 @ 0x0000000016724dbd 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000001671f9ab 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x00000000166f95ff 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x00000000175a3477 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50c28 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:26.961924 [ 2658 ] {c09af9da-8b1b-46fc-8a71-f4e51a34a716} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Access/ContextAccess.cpp: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 @ 0x00000000167265d6 5. ./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 @ 0x0000000016724dbd 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000001671f9ab 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x00000000166f95ff 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x00000000175a3477 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50c28 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:27.133927 [ 2658 ] {47580e2b-ede0-4987-91a8-c7e2ef25b810} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49114) (comment: 00305_http_and_readonly.sh) (in query: DROP TABLE table_00305a ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000167187d9 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 @ 0x000000001671705d 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 @ 0x00000000166f920a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x00000000175a2a1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6b50b 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:27.134948 [ 2658 ] {47580e2b-ede0-4987-91a8-c7e2ef25b810} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000167187d9 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 @ 0x000000001671705d 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 @ 0x00000000166f920a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x00000000175a2a1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6b50b 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:27.396612 [ 2658 ] {0f0cc777-edfa-439b-8d9c-dfc4b2d52ae1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54484) (comment: 00305_http_and_readonly.sh) (in query: DROP DATABASE IF EXISTS test_yihsr1fe ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:27.397395 [ 2658 ] {0f0cc777-edfa-439b-8d9c-dfc4b2d52ae1} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:28.178690 [ 2656 ] {c63a4d32-7dee-4c1f-81dc-7806ace8c5d5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54730) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:28.179883 [ 2656 ] {c63a4d32-7dee-4c1f-81dc-7806ace8c5d5} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:28.195609 [ 2658 ] {63f3d8a8-f535-451a-a39a-c94e3ac9a242} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43002) (comment: 01307_multiple_leaders_zookeeper.sh) (in query: INSERT INTO r0 SELECT number * 2 + 0 FROM numbers(200)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:28.235893 [ 2658 ] {63f3d8a8-f535-451a-a39a-c94e3ac9a242} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:28.939158 [ 3269 ] {} adf9ac46-d24b-4593-9e95-f038dee98299::all_0_14_2 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:28.939704 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {adf9ac46-d24b-4593-9e95-f038dee98299::all_0_14_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:29.713106 [ 3274 ] {} b49c9e90-640d-48ef-8885-5400ee5fa7e0::all_76_84_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:29.714009 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b49c9e90-640d-48ef-8885-5400ee5fa7e0::all_76_84_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:30.346845 [ 3849 ] {547c4c08-2b6e-477a-8dc2-3ee4531bda20} 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.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_myjw9yvt.src UUID '39f64183-7061-4250-b36d-54f683a98602' (`p` UInt64, `k` String, `d` UInt64) ENGINE = MergeTree PARTITION BY p ORDER BY k SETTINGS index_granularity = 63339, min_bytes_for_wide_part = 51444114, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 410220602, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 6076801, merge_max_block_size = 19310, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 494588, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 6899992, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 96765, primary_key_compress_block_size = 15125), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 21. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 22. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:30.417594 [ 3849 ] {547c4c08-2b6e-477a-8dc2-3ee4531bda20} 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.10057.altinitytest (altinity build)) (from [::1]:43086) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: CREATE TABLE src (`p` UInt64, `k` String, `d` UInt64) ENGINE = MergeTree PARTITION BY p ORDER BY k SETTINGS index_granularity = 63339, min_bytes_for_wide_part = 51444114, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 410220602, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 6076801, merge_max_block_size = 19310, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 494588, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 6899992, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 96765, primary_key_compress_block_size = 15125), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 21. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 22. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:30.418395 [ 3849 ] {547c4c08-2b6e-477a-8dc2-3ee4531bda20} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 21. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 22. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:30.748464 [ 3966 ] {18243961-b319-483f-a51d-9b1d214fec72} DatabaseReplicated (test_myjw9yvt): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.12 18:56:30.828781 [ 3966 ] {18243961-b319-483f-a51d-9b1d214fec72} 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.10057.altinitytest (altinity build)) (from [::1]:43146) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: CREATE TABLE dst_r1 (`p` UInt64, `k` String, `d` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/00626_replace_partition_from_table_zookeeper_test_myjw9yvt/dst_1', '1') PARTITION BY p ORDER BY k SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 1, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 63339, min_bytes_for_wide_part = 51444114, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 410220602, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 6076801, merge_max_block_size = 19310, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 494588, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 6899992, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 96765, primary_key_compress_block_size = 15125), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x00000000170efaa7 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000170f1c8d 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f240b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:30.829469 [ 3966 ] {18243961-b319-483f-a51d-9b1d214fec72} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x00000000170efaa7 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000170f1c8d 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f240b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:30.958738 [ 3275 ] {} b49c9e90-640d-48ef-8885-5400ee5fa7e0::all_114_122_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:30.959590 [ 3275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b49c9e90-640d-48ef-8885-5400ee5fa7e0::all_114_122_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:31.165622 [ 4252 ] {fee59dbf-9082-4e52-928b-fb46c46909a8} DatabaseReplicated (test_myjw9yvt): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.12 18:56:31.166706 [ 4252 ] {fee59dbf-9082-4e52-928b-fb46c46909a8} 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.10057.altinitytest (altinity build)) (from [::1]:43178) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: CREATE TABLE dst_r2 (`p` UInt64, `k` String, `d` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/00626_replace_partition_from_table_zookeeper_test_myjw9yvt/dst_1', '2') PARTITION BY p ORDER BY k SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 1, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 63339, min_bytes_for_wide_part = 51444114, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 410220602, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 6076801, merge_max_block_size = 19310, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 494588, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 6899992, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 96765, primary_key_compress_block_size = 15125), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x00000000170efaa7 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000170f1c8d 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f240b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.167290 [ 4252 ] {fee59dbf-9082-4e52-928b-fb46c46909a8} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x00000000170efaa7 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000170f1c8d 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f240b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.374206 [ 4083 ] {cee2d655-7e05-49b2-9ceb-1e1bef774671} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43108) (comment: 01683_flat_dictionary.sql) (in query: DROP DICTIONARY 01681_database_for_flat_dictionary.flat_dictionary_simple_key_simple_attributes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.375216 [ 4083 ] {cee2d655-7e05-49b2-9ceb-1e1bef774671} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.498210 [ 3278 ] {} adf9ac46-d24b-4593-9e95-f038dee98299::all_131_138_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:31.499034 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {adf9ac46-d24b-4593-9e95-f038dee98299::all_131_138_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:31.571931 [ 3921 ] {20ba6f1c-e058-4815-9d2b-08ef2b75f88b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=731, jobs=715). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43200) (comment: 00145_aggregate_functions_statistics.sql) (in query: SELECT varSamp(ResolutionWidth) FROM (SELECT ResolutionWidth FROM test.hits LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.572832 [ 3921 ] {20ba6f1c-e058-4815-9d2b-08ef2b75f88b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=731, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.664099 [ 4101 ] {22449a57-498e-412c-8e6c-26ab68c72c29} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.src does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43196) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.664789 [ 4101 ] {22449a57-498e-412c-8e6c-26ab68c72c29} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.867182 [ 3921 ] {5033ec26-30ef-4956-9a5c-921bc7ab0aa4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43230) (comment: 03031_tuple_elimination_analyzer.sql) (in query: CREATE TABLE test (`id` LowCardinality(UInt32)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 11284, min_bytes_for_wide_part = 462521268, 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 = 391937464, compact_parts_max_bytes_to_buffer = 357323761, compact_parts_max_granules_to_buffer = 218, compact_parts_merge_max_bytes_to_prefetch_part = 14214427, merge_max_block_size = 869, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 6956994001, vertical_merge_algorithm_min_rows_to_activate = 98279, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3405155729, index_granularity_bytes = 17724360, concurrent_part_removal_threshold = 43, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 94643, primary_key_compress_block_size = 18545 AS 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:31.870708 [ 3921 ] {5033ec26-30ef-4956-9a5c-921bc7ab0aa4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:32.021936 [ 3849 ] {381bfcda-6337-4b42-8d54-6e6205462910} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50732) (comment: 03031_tuple_elimination_analyzer.sql) (in query: DROP DATABASE IF EXISTS test_ukvov74x ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:32.022731 [ 3849 ] {381bfcda-6337-4b42-8d54-6e6205462910} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:32.085002 [ 3967 ] {bd50fb17-3bd9-4611-a0ee-b05608f5d030} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.src does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43858) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:32.085563 [ 3967 ] {bd50fb17-3bd9-4611-a0ee-b05608f5d030} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:32.089881 [ 4083 ] {653a1744-abce-4a7c-b917-87ac9a79239c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50738) (comment: 03031_tuple_elimination_analyzer.sql) (in query: DROP DATABASE IF EXISTS test_ukvov74x ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:32.090743 [ 4083 ] {653a1744-abce-4a7c-b917-87ac9a79239c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:32.414152 [ 3275 ] {} b49c9e90-640d-48ef-8885-5400ee5fa7e0::all_193_199_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:32.415146 [ 3275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b49c9e90-640d-48ef-8885-5400ee5fa7e0::all_193_199_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:32.435038 [ 4101 ] {088ee189-3991-440a-aab1-6a3842b8a96f} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43242) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT toIntervalSecond(now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&&) @ 0x00000000079e1d1c 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000079db244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:32.435768 [ 4101 ] {088ee189-3991-440a-aab1-6a3842b8a96f} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&&) @ 0x00000000079e1d1c 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000079db244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:32.483998 [ 3966 ] {4be1a146-1990-4f54-9a9e-45a21f3e4b4a} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.src does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43862) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:32.484415 [ 3966 ] {4be1a146-1990-4f54-9a9e-45a21f3e4b4a} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:32.756057 [ 4101 ] {00174fc6-7362-42de-8e02-8f39d8e98a97} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43242) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT CAST(now64() AS IntervalSecond);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&&) @ 0x00000000079e1d1c 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000079db244 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007632b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779593f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017db93b0 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 30. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 2025.06.12 18:56:32.756693 [ 4101 ] {00174fc6-7362-42de-8e02-8f39d8e98a97} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&&) @ 0x00000000079e1d1c 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000079db244 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007632b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779593f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017db93b0 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 30. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 2025.06.12 18:56:32.763978 [ 4101 ] {36264205-5c2d-4d91-832b-440f0ad1eca8} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43242) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT toIntervalSecond(now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&&) @ 0x00000000079e1d1c 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000079db244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:32.764514 [ 4101 ] {36264205-5c2d-4d91-832b-440f0ad1eca8} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&&) @ 0x00000000079e1d1c 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000079db244 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:32.771315 [ 4101 ] {b6c487ac-d99f-44b4-92b3-5b61f741bc28} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43242) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT CAST(now64() AS IntervalSecond);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&&) @ 0x00000000079e1d1c 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000079db244 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007632b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779593f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017db93b0 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 30. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 2025.06.12 18:56:32.771794 [ 4101 ] {b6c487ac-d99f-44b4-92b3-5b61f741bc28} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&&) @ 0x00000000079e1d1c 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000079db244 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007632b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779593f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017db93b0 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 30. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 2025.06.12 18:56:32.856695 [ 4213 ] {b4b404c4-e0c2-4d8d-813a-99253a78ec46} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.src does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43888) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:32.857099 [ 4213 ] {b4b404c4-e0c2-4d8d-813a-99253a78ec46} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:33.367805 [ 3967 ] {830dab68-2c71-43ac-b8fc-818705c9ffd3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50810) (comment: 00701_join_default_strictness.sql) (in query: DROP DATABASE IF EXISTS test_ei8dgdpj ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:33.368657 [ 3967 ] {830dab68-2c71-43ac-b8fc-818705c9ffd3} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:33.598431 [ 3966 ] {b6adc4e1-6932-43a5-bf80-5fada47688fe} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43940) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO dst_r1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:33.599097 [ 3966 ] {b6adc4e1-6932-43a5-bf80-5fada47688fe} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:33.936870 [ 4252 ] {30186f6e-25e4-4b4a-9bec-ba74d807b08d} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43982) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO dst_r1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:33.937227 [ 4252 ] {30186f6e-25e4-4b4a-9bec-ba74d807b08d} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:34.267386 [ 4203 ] {2f19406a-8384-4c85-8d1b-371457f4ec78} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44012) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO dst_r1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:34.267769 [ 4203 ] {2f19406a-8384-4c85-8d1b-371457f4ec78} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:34.365463 [ 4213 ] {5519d644-3bb7-47a0-af1e-a21f5f72870e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43980) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() FROM test.hits WHERE CounterID > (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:34.366066 [ 4213 ] {5519d644-3bb7-47a0-af1e-a21f5f72870e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:34.565802 [ 4031 ] {} test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:56:34.679734 [ 3961 ] {09319268-cb6c-4f46-9db9-f095094b401b} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44038) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:34.688913 [ 3961 ] {09319268-cb6c-4f46-9db9-f095094b401b} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:34.760634 [ 4031 ] {} DatabaseCatalog: Cannot drop table test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299). Will retry later.: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:35.164378 [ 3921 ] {b43fe2a5-1139-4f58-ab71-d1ec223d694d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL AS `ym:ah:URL`, sum((NOT DontCountHits) AND (NOT Refresh)), quantilesTimingIf(0.1, 0.5, 0.9)(DOMCompleteTiming + LoadEventEndTiming, (DOMCompleteTiming != -1) AND (LoadEventEndTiming != -1)) AS t FROM remote('127.0.0.{1,2}', test, hits) WHERE (CounterID = 800784) AND (((DontCountHits = 0) OR (IsNotBounce = 1)) AND (URL != '')) GROUP BY `ym:ah:URL` WITH TOTALS HAVING (sum((NOT DontCountHits) AND (NOT Refresh)) > 0) AND (count() > 0) ORDER BY sum((NOT DontCountHits) AND (NOT Refresh)) DESC, URL ASC LIMIT 0, 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44064) (comment: 00010_quantiles_segfault.sql) (in query: SELECT URL AS `ym:ah:URL`, sum((NOT DontCountHits AND NOT Refresh)), quantilesTimingIf(0.1, 0.5, 0.9)((DOMCompleteTiming + LoadEventEndTiming), DOMCompleteTiming != -1 AND LoadEventEndTiming != -1) as t FROM remote('127.0.0.{1,2}', test, hits) WHERE (CounterID = 800784) AND (((DontCountHits = 0) OR (IsNotBounce = 1)) AND (URL != '')) GROUP BY `ym:ah:URL` WITH TOTALS HAVING (sum((NOT DontCountHits AND NOT Refresh)) > 0) AND (count() > 0) ORDER BY sum((NOT DontCountHits AND NOT Refresh)) DESC, URL LIMIT 0, 1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174d629c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749bddf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.166105 [ 3921 ] {b43fe2a5-1139-4f58-ab71-d1ec223d694d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL AS `ym:ah:URL`, sum((NOT DontCountHits) AND (NOT Refresh)), quantilesTimingIf(0.1, 0.5, 0.9)(DOMCompleteTiming + LoadEventEndTiming, (DOMCompleteTiming != -1) AND (LoadEventEndTiming != -1)) AS t FROM remote('127.0.0.{1,2}', test, hits) WHERE (CounterID = 800784) AND (((DontCountHits = 0) OR (IsNotBounce = 1)) AND (URL != '')) GROUP BY `ym:ah:URL` WITH TOTALS HAVING (sum((NOT DontCountHits) AND (NOT Refresh)) > 0) AND (count() > 0) ORDER BY sum((NOT DontCountHits) AND (NOT Refresh)) DESC, URL ASC LIMIT 0, 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174d629c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749bddf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.171605 [ 4203 ] {a08bcebd-aaeb-400f-a346-de7f7038ef90} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT count(), sum(d) FROM src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44070) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.172172 [ 4203 ] {a08bcebd-aaeb-400f-a346-de7f7038ef90} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT count(), sum(d) FROM src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.271838 [ 3961 ] {dd7e7bdb-b0f6-40c9-ba3e-c60aed623935} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44078) (comment: 02012_zookeeper_changed_enum_type_incompatible.sql) (in query: insert into enum_alter_issue 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d92d 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447e8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.272771 [ 3961 ] {dd7e7bdb-b0f6-40c9-ba3e-c60aed623935} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7)) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d92d 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447e8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.488614 [ 3961 ] {d8331f23-89fc-462f-89e7-c0916c9a8232} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44100) (comment: 00062_loyalty.sql) (in query: SELECT loyalty, count() AS c, bar(log(c + 1) * 1000, 0, log(6000) * 1000, 80) FROM (SELECT UserID, toInt8((yandex > google ? yandex / (yandex + google) : -google / (yandex + google)) * 10) AS loyalty FROM (SELECT UserID, sum(SearchEngineID = 2) AS yandex, sum(SearchEngineID = 3) AS google FROM test.hits WHERE SearchEngineID = 2 OR SearchEngineID = 3 GROUP BY UserID HAVING yandex + google > 10)) GROUP BY loyalty ORDER BY loyalty), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.491649 [ 3967 ] {bc1f36eb-cb3a-492d-9bf4-7d3cd76650bb} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50972) (comment: 02012_zookeeper_changed_enum_type_incompatible.sql) (in query: DROP DATABASE IF EXISTS test_1a87k00g ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d92d 5. ./src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a967 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>>>&) @ 0x0000000017c6e9aa 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.492449 [ 3967 ] {bc1f36eb-cb3a-492d-9bf4-7d3cd76650bb} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7)) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d92d 5. ./src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a967 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>>>&) @ 0x0000000017c6e9aa 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:35.498918 [ 3961 ] {d8331f23-89fc-462f-89e7-c0916c9a8232} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.512751 [ 4101 ] {390bd809-6c78-4c64-829f-ae11c359dc96} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44104) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.513275 [ 4101 ] {390bd809-6c78-4c64-829f-ae11c359dc96} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.769921 [ 3961 ] {54d9e8be-ae20-465b-b9a5-56276b8b2d68} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44142) (comment: 00056_view.sql) (in query: SELECT count() FROM test.view;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.770813 [ 3961 ] {54d9e8be-ae20-465b-b9a5-56276b8b2d68} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.852588 [ 3921 ] {8d01c69e-7793-4b47-93dd-2b86922a2805} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44154) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:35.853137 [ 3921 ] {8d01c69e-7793-4b47-93dd-2b86922a2805} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:36.104116 [ 3961 ] {87ed4f12-91a6-48c1-8a06-8850bdbade3a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44200) (comment: 00139_like.sql) (in query: /* Note that queries are written as the user doesn't really understand that the symbol _ has special meaning in LIKE pattern. */ SELECT count() FROM test.hits WHERE URL LIKE '%/avtomobili_s_probegom/_%__%__%__%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:36.105729 [ 3961 ] {87ed4f12-91a6-48c1-8a06-8850bdbade3a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:36.783048 [ 4101 ] {e25dca4f-5784-4d0d-9601-07c2b92e718c} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44264) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:36.783689 [ 4101 ] {e25dca4f-5784-4d0d-9601-07c2b92e718c} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:36.946952 [ 4203 ] {2516f52a-e00e-414d-bd52-9bba031f33c6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44098) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 153437;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:36.948536 [ 4203 ] {2516f52a-e00e-414d-bd52-9bba031f33c6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:38.028283 [ 3849 ] {70f64d6f-7420-4a1a-8b5d-f654c30b82aa} executeQuery: Code: 264. DB::Exception: Table test.join (a15a9925-612a-4035-9fd8-5f871ebb481b) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44326) (comment: 00065_loyalty_with_storage_join.sql) (in query: SELECT loyalty, count() FROM hits SEMI LEFT JOIN join USING UserID GROUP BY loyalty ORDER BY loyalty ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000001922186e 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&) @ 0x0000000017e10cf4 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&) @ 0x0000000017df0110 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&) @ 0x0000000017de0b12 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:38.029677 [ 3849 ] {70f64d6f-7420-4a1a-8b5d-f654c30b82aa} TCPHandler: Code: 264. DB::Exception: Table test.join (a15a9925-612a-4035-9fd8-5f871ebb481b) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000001922186e 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&) @ 0x0000000017e10cf4 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&) @ 0x0000000017df0110 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&) @ 0x0000000017de0b12 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:38.123212 [ 3389 ] {} virtual void DB::SystemLog::savingThreadFunction() [LogElement = DB::QueryViewsLogElement]: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/SystemLog.cpp:0: DB::SystemLog::prepareTable() @ 0x000000001800e733 18. ./build_docker/./src/Interpreters/SystemLog.cpp:0: DB::SystemLog::savingThreadFunction() @ 0x000000001800fa57 19. ./build_docker/./src/Common/SystemLogBase.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000000fb7c95a 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb7c8a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:38.504844 [ 3550 ] {dbd815fb-464d-4073-9cac-8a89c62384e4} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44286) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 1000000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000173e9832 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:270: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x00000000173ea188 15. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:517: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000001743e50e 16. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:627: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000001743569a 17. ./src/Interpreters/ActionsDAG.h:120: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000017450e43 18. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:0: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000017e1e779 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:515: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc31a1 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:56:38.505501 [ 3550 ] {dbd815fb-464d-4073-9cac-8a89c62384e4} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000173e9832 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:270: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x00000000173ea188 15. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:517: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000001743e50e 16. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:627: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000001743569a 17. ./src/Interpreters/ActionsDAG.h:120: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000017450e43 18. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:0: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000017e1e779 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:515: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc31a1 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:56:38.828105 [ 3550 ] {bb5e44a0-877a-49f0-b44f-2fa95ab699e4} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100000)). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44286) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.828693 [ 3550 ] {bb5e44a0-877a-49f0-b44f-2fa95ab699e4} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100000)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.841937 [ 3550 ] {7e2a3511-6399-4e60-afc5-6398bd2353fe} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10000)). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44286) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 10000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.842395 [ 3550 ] {7e2a3511-6399-4e60-afc5-6398bd2353fe} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10000)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.850883 [ 3550 ] {c0398b08-2ce8-4075-a6a7-6c6631851daf} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1000)). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44286) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.851293 [ 3550 ] {c0398b08-2ce8-4075-a6a7-6c6631851daf} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1000)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.857300 [ 3550 ] {97cb2608-9c25-4761-8ad3-9969197fbbea} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100)). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44286) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 100));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.857711 [ 3550 ] {97cb2608-9c25-4761-8ad3-9969197fbbea} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.863694 [ 3550 ] {51710959-7394-4e9a-af22-04abb6ca0787} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10)). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44286) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.864137 [ 3550 ] {51710959-7394-4e9a-af22-04abb6ca0787} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.869910 [ 3550 ] {83087de4-07b3-4dc2-91cf-5c1482850115} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1)). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44286) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:38.870311 [ 3550 ] {83087de4-07b3-4dc2-91cf-5c1482850115} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000b614a89 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b6135a9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:56:39.996579 [ 3369 ] {} test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:56:40.137603 [ 3849 ] {2e835a21-8559-4702-96d5-9bb216eeec72} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44502) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:40.138227 [ 3849 ] {2e835a21-8559-4702-96d5-9bb216eeec72} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:40.213786 [ 3369 ] {} DatabaseCatalog: Cannot drop table test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299). Will retry later.: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:40.335248 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:41.336107 [ 2723 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:41.446293 [ 4083 ] {74cc1e85-b175-4f44-a386-93b8067ba12a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44636) (comment: 00145_aggregate_functions_statistics.sql) (in query: SELECT covarSamp(ResolutionWidth, ResolutionHeight) FROM (SELECT ResolutionWidth, ResolutionHeight FROM test.hits LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:41.448290 [ 4083 ] {74cc1e85-b175-4f44-a386-93b8067ba12a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:42.339479 [ 3166 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:42.901485 [ 3826 ] {ccbd3a61-5162-4bde-a786-3f849b4832ec} executeQuery: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50760) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:42.902389 [ 3826 ] {ccbd3a61-5162-4bde-a786-3f849b4832ec} TCPHandler: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:43.340240 [ 3131 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:43.473207 [ 2656 ] {15e8d9a0-f188-4292-8394-7184fcde2eed} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50790) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:43.473747 [ 2656 ] {15e8d9a0-f188-4292-8394-7184fcde2eed} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:43.649572 [ 5737 ] {327ba8c9-5da2-4935-a83c-eff904deb2b5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50782) (comment: 00145_aggregate_functions_statistics.sql) (in query: SELECT round(varSamp(ResolutionWidth), 6) FROM test.hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:43.650703 [ 5737 ] {327ba8c9-5da2-4935-a83c-eff904deb2b5} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:44.098219 [ 3967 ] {92389e44-2c6a-414a-899d-609a271a96fa} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60944) (comment: 02884_async_insert_native_protocol_1.sh) (in query: DROP DATABASE IF EXISTS test_vbzil7m9 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:44.099448 [ 3967 ] {92389e44-2c6a-414a-899d-609a271a96fa} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:44.105573 [ 3550 ] {e3ece816-fbfe-4d31-8ffe-5a5a5ee605d9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60956) (comment: 02884_async_insert_native_protocol_1.sh) (in query: DROP DATABASE IF EXISTS test_vbzil7m9 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:44.106205 [ 3550 ] {e3ece816-fbfe-4d31-8ffe-5a5a5ee605d9} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:44.340985 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:44.436392 [ 3550 ] {b9a87adc-cea5-4e0d-85a3-4c6352461bf4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=720). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50828) (comment: 02494_query_cache_user_isolation.sh) (in query: SELECT ProfileEvents['QueryCacheHits'], ProfileEvents['QueryCacheMisses'] FROM system.query_log WHERE type = 'QueryFinish' AND current_database = currentDatabase() AND query = 'SELECT 0 == 82412 SETTINGS use_query_cache = 1' order by event_time_microseconds), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:44.437853 [ 3550 ] {b9a87adc-cea5-4e0d-85a3-4c6352461bf4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=720). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:44.767279 [ 2656 ] {dbd8eb71-a4a5-4b71-8b80-74f5840f0cb4} executeQuery: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50870) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:44.768201 [ 2656 ] {dbd8eb71-a4a5-4b71-8b80-74f5840f0cb4} TCPHandler: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:45.131975 [ 4030 ] {} test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:56:45.135065 [ 4030 ] {} DatabaseCatalog: Cannot drop table test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299). Will retry later.: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:45.342204 [ 3060 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:45.682855 [ 3921 ] {19bd9f41-8ddf-46d6-94d2-247565f45fda} 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.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57074) (comment: 00164_quantileBfloat16.sql) (in query: SELECT `__table1`.`CounterID` AS `k`, quantileBFloat16(0.5)(`__table1`.`ResolutionWidth`) AS `quantileBFloat16(0.5)(ResolutionWidth)` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC, `__table1`.`CounterID` ASC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:45.684040 [ 3921 ] {19bd9f41-8ddf-46d6-94d2-247565f45fda} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:45.722978 [ 2658 ] {807cf0e1-300f-4a00-8dc2-9b41857b1066} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2: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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50920) (comment: 00164_quantileBfloat16.sql) (in query: SELECT CounterID AS k, quantileBFloat16(0.5)(ResolutionWidth) FROM remote('127.0.0.{1,2}', test.hits) GROUP BY k ORDER BY count() DESC, CounterID 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 18:56:45.725050 [ 2658 ] {807cf0e1-300f-4a00-8dc2-9b41857b1066} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2: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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 : 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 18:56:46.343404 [ 3017 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:46.818277 [ 3748 ] {7aba8bc7-5b6c-4515-ac92-facb4b1e61de} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51082) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:46.818793 [ 3748 ] {7aba8bc7-5b6c-4515-ac92-facb4b1e61de} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.042861 [ 3921 ] {48ae40c1-98c6-44d7-9c88-40ec461986a6} executeQuery: Code: 57. DB::Exception: Table test_30tcq8q5.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00174_distinct_in_order.sql) (in query: /* ddl_entry=query-0000000005 */ CREATE TABLE test_30tcq8q5.distinct_in_order UUID 'f4ad0075-481a-4be1-bc10-fcb92a32d981' (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 500579185, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 457862647, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 20898062, merge_max_block_size = 4778, 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 = 91, min_merge_bytes_to_use_direct_io = 5175318072, concurrent_part_removal_threshold = 93, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 59574, primary_key_compress_block_size = 94297), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.047501 [ 3921 ] {48ae40c1-98c6-44d7-9c88-40ec461986a6} executeQuery: Code: 57. DB::Exception: Table test_30tcq8q5.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50996) (comment: 00174_distinct_in_order.sql) (in query: CREATE TABLE distinct_in_order (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 500579185, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 457862647, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 20898062, merge_max_block_size = 4778, 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 = 91, min_merge_bytes_to_use_direct_io = 5175318072, concurrent_part_removal_threshold = 93, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 59574, primary_key_compress_block_size = 94297), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.048985 [ 3921 ] {48ae40c1-98c6-44d7-9c88-40ec461986a6} TCPHandler: Code: 57. DB::Exception: Table test_30tcq8q5.distinct_in_order already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.104104 [ 5737 ] {6f71ee56-869c-4d58-92b2-19dd1bd13a11} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32790) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_30tcq8q5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.105225 [ 5737 ] {6f71ee56-869c-4d58-92b2-19dd1bd13a11} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:47.113109 [ 3921 ] {6b47dc54-4226-4fc4-80fd-70f674921184} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32794) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_30tcq8q5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.114031 [ 3921 ] {6b47dc54-4226-4fc4-80fd-70f674921184} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:47.121008 [ 3844 ] {94d60614-4f3f-4134-82d7-3be3c69ccccc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32810) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_30tcq8q5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.121855 [ 3844 ] {94d60614-4f3f-4134-82d7-3be3c69ccccc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:47.128417 [ 3921 ] {fbe860d7-dd0b-4f90-afcb-a1938cb1dad7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32818) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_30tcq8q5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.129193 [ 3921 ] {fbe860d7-dd0b-4f90-afcb-a1938cb1dad7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:47.134614 [ 3844 ] {3383ca23-673e-4e27-b8bb-1a896d803d98} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32832) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_30tcq8q5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.135205 [ 3844 ] {3383ca23-673e-4e27-b8bb-1a896d803d98} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:47.140185 [ 3921 ] {0a79e25d-db22-4e37-9ad8-5ff5a59e1eb7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32840) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_30tcq8q5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.140839 [ 3921 ] {0a79e25d-db22-4e37-9ad8-5ff5a59e1eb7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:47.344121 [ 2993 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:47.952910 [ 3748 ] {e5c742e7-b5f3-48a6-810b-278e655147e6} executeQuery: Code: 57. DB::Exception: Table test_dhih6ok9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51234) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:47.954088 [ 3748 ] {e5c742e7-b5f3-48a6-810b-278e655147e6} TCPHandler: Code: 57. DB::Exception: Table test_dhih6ok9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:48.357443 [ 2964 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:48.537682 [ 3866 ] {1ed8f1fd-257b-484e-b6dd-5678de15b215} executeQuery: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51318) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:48.538796 [ 3866 ] {1ed8f1fd-257b-484e-b6dd-5678de15b215} TCPHandler: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:49.361474 [ 2945 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:50.099398 [ 4252 ] {ade40258-aa01-4a7a-a522-066c8058d4c8} executeQuery: Code: 57. DB::Exception: Table test_dhih6ok9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51408) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:50.100939 [ 4252 ] {ade40258-aa01-4a7a-a522-066c8058d4c8} TCPHandler: Code: 57. DB::Exception: Table test_dhih6ok9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:50.165603 [ 4203 ] {44ceaedf-b8f4-4aec-9a81-f0571a12fa8a} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51414) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:50.166275 [ 4203 ] {44ceaedf-b8f4-4aec-9a81-f0571a12fa8a} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:50.280420 [ 3659 ] {} test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:56:50.314283 [ 3659 ] {} DatabaseCatalog: Cannot drop table test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299). 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:50.364073 [ 2926 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:50.501244 [ 4083 ] {763388df-2b16-4017-8838-5d8c08ed117b} executeQuery: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51432) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:50.503298 [ 4083 ] {763388df-2b16-4017-8838-5d8c08ed117b} TCPHandler: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:51.365355 [ 2868 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:51.529179 [ 5779 ] {66476ac8-9ec1-4a86-a465-6f5896fa8712} executeQuery: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51460) (comment: 02597_column_update_and_replication.sql) (in query: ALTER TABLE test DROP COLUMN x SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x00000000199e252c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc3f5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:51.529997 [ 5779 ] {66476ac8-9ec1-4a86-a465-6f5896fa8712} TCPHandler: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x00000000199e252c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc3f5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:51.852163 [ 5843 ] {77f622ce-6067-4fae-8abb-bd85d62412a4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33014) (comment: 00162_mmap_compression_none.sql) (in query: DROP DATABASE IF EXISTS test_wfkd0m1n ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:51.853116 [ 5843 ] {77f622ce-6067-4fae-8abb-bd85d62412a4} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:52.370914 [ 2824 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:53.372630 [ 2778 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:53.492333 [ 3967 ] {2859fe6c-6a95-4db1-91f3-f13576b2a596} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45728) (comment: 02188_table_function_format.sql) (in query: create table test as format(JSONEachRow, $$ {"a": "Hello", "b": 111} {"a": "World", "b": 123} {"a": "Hello", "b": 111} {"a": "Hello", "b": 131} {"a": "World", "b": 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:53.498162 [ 3967 ] {2859fe6c-6a95-4db1-91f3-f13576b2a596} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:53.592947 [ 3961 ] {b4346ef0-8202-4e4b-8e72-8c16d69c573a} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45752) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:53.603404 [ 3961 ] {b4346ef0-8202-4e4b-8e72-8c16d69c573a} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:54.374867 [ 2753 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:55.377258 [ 2728 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:56.380336 [ 2702 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:56.947640 [ 5737 ] {7102f94b-2748-427a-873f-c4ff97461461} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46034) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:56.948321 [ 5737 ] {7102f94b-2748-427a-873f-c4ff97461461} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:56:57.387463 [ 3177 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:58.391086 [ 3151 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:56:59.393024 [ 3133 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:00.346675 [ 3748 ] {830cc364-2275-415d-a80d-786bea6c8caf} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46092) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:00.347380 [ 3748 ] {830cc364-2275-415d-a80d-786bea6c8caf} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:00.394783 [ 3102 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:01.149906 [ 3921 ] {0b6cb56d-e406-4332-a79f-0ebe832c3c21} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46088) (comment: 00597_push_down_predicate_long.sql) (in query: EXPLAIN SYNTAX SELECT id FROM (SELECT arrayJoin([1, 2, 3]) AS id) WHERE id = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:01.150210 [ 3921 ] {0b6cb56d-e406-4332-a79f-0ebe832c3c21} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:01.396272 [ 3075 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:02.163926 [ 3921 ] {4225494e-c6ad-43b1-8609-e460e5f7b7c2} 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.10057.altinitytest (altinity build)) (from [::1]:46104) (comment: 02302_projections_GROUP_BY_ORDERY_BY_optimize_aggregation_in_order.sql) (in query: -- { echoOn } select x + y, sum(x - y) as s from test_agg_proj_02302 group by x + y order by s desc limit 5 settings optimize_aggregation_in_order=0, optimize_read_in_order=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:02.171263 [ 3921 ] {4225494e-c6ad-43b1-8609-e460e5f7b7c2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:02.397201 [ 2703 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:03.398408 [ 3019 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:03.689243 [ 3921 ] {489b6a2d-b737-4209-a73c-eb9a715a060c} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60322) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:03.689880 [ 3921 ] {489b6a2d-b737-4209-a73c-eb9a715a060c} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:04.401461 [ 2998 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:04.499599 [ 3380 ] {} test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:57:04.510342 [ 3380 ] {} DatabaseCatalog: Cannot drop table test_3.r0 (adf9ac46-d24b-4593-9e95-f038dee98299). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:04.567185 [ 5737 ] {1b7417ba-84a5-4e4e-95ee-805d94fbddec} executeQuery: Code: 57. DB::Exception: Table test.hits_tinylog already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46078) (comment: 00077_log_tinylog_stripelog.sql) (in query: CREATE TABLE test.hits_tinylog (CounterID UInt32, AdvEngineID UInt8, RegionID UInt32, SearchPhrase String, UserID UInt64) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:04.568549 [ 5737 ] {1b7417ba-84a5-4e4e-95ee-805d94fbddec} TCPHandler: Code: 57. DB::Exception: Table test.hits_tinylog already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:05.266492 [ 3528 ] {ac43bf33-701f-4482-bdd7-1ac3e865246b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60362) (comment: 00172_early_constant_folding.sql) (in query: EXPLAIN PIPELINE SELECT count(JavaEnable) FROM test.hits WHERE WatchID = 1 OR Title = 'next' OR URL = 'prev' OR URL = '???' OR 1 SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000017e440a9 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000017e44b63 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4449e 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4484c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018213862 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:05.274807 [ 3528 ] {ac43bf33-701f-4482-bdd7-1ac3e865246b} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000017e440a9 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000017e44b63 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4449e 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4484c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018213862 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:05.403057 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:05.451585 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c86f717d-83e3-4b01-97b8-8250998cbdff::202506_1_23_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:05.896488 [ 3826 ] {cc60d07e-38cb-4e34-a700-c6e4baa20bb5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60416) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT * FROM parsing_with_names;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:05.897315 [ 3826 ] {cc60d07e-38cb-4e34-a700-c6e4baa20bb5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:05.946970 [ 3528 ] {1e6f92f6-b865-413c-901b-4db1f5cf1ced} 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.10057.altinitytest (altinity build)) (from [::1]:60412) (comment: 02815_range_dict_no_direct_join.sql) (in query: SELECT id, amount FROM ids INNER JOIN discounts_dict ON id = advertiser_id ORDER BY id, amount SETTINGS join_algorithm = 'direct,hash';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:05.948274 [ 3528 ] {1e6f92f6-b865-413c-901b-4db1f5cf1ced} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:06.405794 [ 2955 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:06.560014 [ 3748 ] {1be8cab1-0560-4e78-b114-3188b356cb9d} 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.10057.altinitytest (altinity build)) (from [::1]:60428) (comment: 02861_filter_pushdown_const_bug.sql) (in query: SELECT * FROM ( SELECT 1 AS key GROUP BY NULL ) AS t1 INNER JOIN (SELECT 1 AS key) AS t2 ON t1.key = t2.key WHERE t1.key 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:06.563248 [ 3748 ] {1be8cab1-0560-4e78-b114-3188b356cb9d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:06.689345 [ 3826 ] {57b94f05-7157-4951-a75f-e21c7708e79d} executeQuery: Code: 57. DB::Exception: Table test_dhih6ok9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60446) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:06.690344 [ 3826 ] {57b94f05-7157-4951-a75f-e21c7708e79d} TCPHandler: Code: 57. DB::Exception: Table test_dhih6ok9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:07.062959 [ 3921 ] {a7e0128b-2a7c-46b8-a248-458b24b8eacf} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60456) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:07.063868 [ 3921 ] {a7e0128b-2a7c-46b8-a248-458b24b8eacf} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:07.407936 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:08.409337 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:08.567793 [ 3528 ] {c05221ee-1ad9-4ccc-94f3-878b30a33369} 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.10057.altinitytest (altinity build)) (from [::1]:60508) (comment: 00061_storage_buffer.sql) (in query: OPTIMIZE TABLE test.hits_buffer;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195e521c 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000195e4e70 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:08.569514 [ 3528 ] {c05221ee-1ad9-4ccc-94f3-878b30a33369} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195e521c 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000195e4e70 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:09.410424 [ 2896 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:09.878632 [ 3450 ] {} test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:57:09.881128 [ 3450 ] {} DatabaseCatalog: Cannot drop table test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0). Will retry later.: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:10.411435 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:10.460766 [ 3865 ] {f54ed282-a54f-4d3c-827c-21599760b69d} executeQuery: Code: 497. DB::Exception: test_15_restricted_user_2952811554: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_15.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60628) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO table_with_default (key) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 25. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 26. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 18:57:10.474058 [ 3865 ] {f54ed282-a54f-4d3c-827c-21599760b69d} TCPHandler: Code: 497. DB::Exception: test_15_restricted_user_2952811554: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_15.dict, 'value', key) String : 5'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 25. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 26. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 18:57:10.478581 [ 5738 ] {07d2de00-b068-4841-9091-6d89656ca117} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60676) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:10.479436 [ 5738 ] {07d2de00-b068-4841-9091-6d89656ca117} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:10.822721 [ 3550 ] {28442088-1e85-4567-bfec-fcb961ca0a6b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT count(), sum(d) FROM src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60736) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:10.823467 [ 3550 ] {28442088-1e85-4567-bfec-fcb961ca0a6b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT count(), sum(d) FROM src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:11.193822 [ 5737 ] {40ac36cc-0d02-48a2-b088-7a46e0d57a54} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60742) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:11.220026 [ 5737 ] {40ac36cc-0d02-48a2-b088-7a46e0d57a54} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:11.250889 [ 5778 ] {bcb52707-4578-45a2-93ce-9af283d919b3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60682) (comment: 00990_hasToken.sh) (in query: SELECT hasToken('needlehayhayhayhayhayhayhayhayhayhayhayhayhayhayhayhayhayhay', 'needle'), ' expecting ', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:11.251699 [ 5778 ] {bcb52707-4578-45a2-93ce-9af283d919b3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:11.409832 [ 3460 ] {e7221a41-d0e4-475d-9032-a2ca8892c0f1} executeQuery: Code: 497. DB::Exception: test_15_restricted_user_2952811554: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_15.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO test_15.table_with_default (key) FORMAT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550f4a 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 18:57:11.411001 [ 3460 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_15.table_with_default (key) FORMAT Values': Code: 497. DB::Exception: test_15_restricted_user_2952811554: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_15.dict, 'value', key) String : 5'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550f4a 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:11.412964 [ 3967 ] {e367a1c3-b24d-4ccf-aeb5-2f7a51286a26} executeQuery: Code: 497. DB::Exception: test_15_restricted_user_2952811554: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_15.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60728) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO table_with_default (key) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550f4a 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 18:57:11.414586 [ 3967 ] {e367a1c3-b24d-4ccf-aeb5-2f7a51286a26} TCPHandler: Code: 497. DB::Exception: test_15_restricted_user_2952811554: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_15.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550f4a 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 18:57:11.472343 [ 2862 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:11.613975 [ 3550 ] {7bd77e42-5aca-4e8f-b3c4-afd8cb273bdf} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60764) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:11.614886 [ 3550 ] {7bd77e42-5aca-4e8f-b3c4-afd8cb273bdf} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:12.473542 [ 2832 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:12.514025 [ 3550 ] {b3fed674-36c0-456a-b45e-9910057eaf27} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57192) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:12.514695 [ 3550 ] {b3fed674-36c0-456a-b45e-9910057eaf27} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:12.566988 [ 3866 ] {a12c42d0-1ac9-4aab-91af-813d0738a813} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57188) (comment: 00020_distinct_order_by_distributed.sql) (in query: SELECT count() FROM (SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:12.568596 [ 3866 ] {a12c42d0-1ac9-4aab-91af-813d0738a813} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:13.474767 [ 2978 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:13.991112 [ 4203 ] {edef42f2-804d-43ec-b2d6-e158a3c257e3} executeQuery: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57270) (comment: 01817_storage_buffer_parameters.sql) (in query: -- not enough args create table buffer_01817 (key Int) Engine=Buffer(currentDatabase(), data_01817, /* num_layers= */ 1, /* min_time= */ 1, /* max_time= */ 86400, /* min_rows= */ 1e9, /* max_rows= */ 1e6, /* min_bytes= */ 0 /* max_bytes= 4e6 */ );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageBuffer.cpp:1203: 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&) @ 0x00000000195eca5c 5. ./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 @ 0x00000000191ba866 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:13.992259 [ 4203 ] {edef42f2-804d-43ec-b2d6-e158a3c257e3} TCPHandler: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageBuffer.cpp:1203: 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&) @ 0x00000000195eca5c 5. ./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 @ 0x00000000191ba866 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:14.001037 [ 4203 ] {05a2795a-2c3c-49a0-a401-a3626b0b05f5} executeQuery: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57270) (comment: 01817_storage_buffer_parameters.sql) (in query: -- too much args create table buffer_01817 (key Int) Engine=Buffer(currentDatabase(), data_01817, /* num_layers= */ 1, /* min_time= */ 1, /* max_time= */ 86400, /* min_rows= */ 1e9, /* max_rows= */ 1e6, /* min_bytes= */ 0, /* max_bytes= */ 4e6, /* flush_time= */ 86400, /* flush_rows= */ 10, /* flush_bytes= */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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageBuffer.cpp:1203: 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&) @ 0x00000000195eca5c 5. ./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 @ 0x00000000191ba866 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:14.002007 [ 4203 ] {05a2795a-2c3c-49a0-a401-a3626b0b05f5} TCPHandler: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageBuffer.cpp:1203: 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&) @ 0x00000000195eca5c 5. ./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 @ 0x00000000191ba866 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:14.057734 [ 3450 ] {} test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:57:14.062901 [ 3450 ] {} DatabaseCatalog: Cannot drop table test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0). Will retry later.: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:14.135129 [ 4203 ] {73b31f6d-55fd-4f07-8a5a-5f5d98149f93} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57270) (comment: 01817_storage_buffer_parameters.sql) (in query: drop table data_01817;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:14.135814 [ 4203 ] {73b31f6d-55fd-4f07-8a5a-5f5d98149f93} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:14.366162 [ 3550 ] {0af278aa-85dd-4809-9f95-32f177fdf538} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60098) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:14.367638 [ 3550 ] {0af278aa-85dd-4809-9f95-32f177fdf538} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:14.374634 [ 3866 ] {4ffc9b55-2912-4d33-9d5d-5ad36cd09de4} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=735). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57302) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 18:57:14.377346 [ 3866 ] {4ffc9b55-2912-4d33-9d5d-5ad36cd09de4} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=735). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 : 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 18:57:14.475574 [ 2778 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:15.476588 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:15.933747 [ 3966 ] {182204ca-d386-4125-8761-67920748d193} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57398) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:15.934768 [ 3966 ] {182204ca-d386-4125-8761-67920748d193} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:16.155424 [ 3826 ] {a7b68130-b126-4ada-8478-ee267b9c85a1} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57410) (comment: 00022_merge_prewhere.sql) (in query: DROP TABLE test.merge_hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:16.156463 [ 3826 ] {a7b68130-b126-4ada-8478-ee267b9c85a1} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:16.477703 [ 2741 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:17.478923 [ 2726 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:18.082805 [ 5779 ] {721bb9f6-53f3-48fa-b6ad-9a5bb7bc1728} 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.10057.altinitytest (altinity build)) (from [::1]:57540) (comment: 00046_uniq_upto_distributed.sql) (in query: SELECT RegionID, uniqExact(UserID) AS u1, uniqUpTo(10)(UserID) AS u2 FROM remote('127.0.0.{1,2}', test, visits) GROUP BY RegionID HAVING u1 <= 11 AND u1 != u2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:18.085157 [ 5779 ] {721bb9f6-53f3-48fa-b6ad-9a5bb7bc1728} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:18.480123 [ 2708 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:18.535683 [ 3921 ] {433e91d2-046b-499c-b3c8-11d9986170a3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57554) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count() FROM (SELECT arrayJoin(cache_paths) AS cache_path, local_path, remote_path FROM system.remote_data_paths ) AS data_paths INNER JOIN system.filesystem_cache AS caches ON data_paths.cache_path = caches.cache_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:18.537951 [ 3921 ] {433e91d2-046b-499c-b3c8-11d9986170a3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:19.336415 [ 3865 ] {d26be28e-b2f5-4d07-8740-a1aef424fa7c} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57640) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:19.336897 [ 3865 ] {d26be28e-b2f5-4d07-8740-a1aef424fa7c} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:19.481384 [ 2691 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:19.561223 [ 8302 ] {} test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:57:19.562058 [ 8302 ] {} DatabaseCatalog: Cannot drop table test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0). 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:19.729257 [ 5778 ] {c8d98f70-1cf5-4f08-8727-14ed9b557136} 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.10057.altinitytest (altinity build)) (from [::1]:57664) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count() FROM system.filesystem_cache WHERE cache_hits > 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:19.730628 [ 5778 ] {c8d98f70-1cf5-4f08-8727-14ed9b557136} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:20.047738 [ 2658 ] {d47ef716-34a5-49db-8c18-69b7b3e4d26a} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57686) (comment: 02400_memory_accounting_on_error.sql) (in query: -- max_block_size to avoid randomization SELECT * FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536 SETTINGS max_memory_usage='1Gi', max_block_size=65505, log_queries=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9bd41a 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000007622af1 9. ./src/Common/PODArray.h:315: 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) @ 0x00000000192063f3 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) @ 0x0000000019208981 11. ./contrib/llvm-project/libcxx/include/vector:1629: DB::(anonymous namespace)::GenerateSource::generate() @ 0x0000000019204e56 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:20.048569 [ 2658 ] {d47ef716-34a5-49db-8c18-69b7b3e4d26a} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 1.00 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9bd41a 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000007622af1 9. ./src/Common/PODArray.h:315: 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) @ 0x00000000192063f3 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) @ 0x0000000019208981 11. ./contrib/llvm-project/libcxx/include/vector:1629: DB::(anonymous namespace)::GenerateSource::generate() @ 0x0000000019204e56 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:20.213965 [ 3849 ] {1c170e0a-106b-4005-9441-b60209ded3c5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57722) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count() FROM system.filesystem_cache WHERE cache_hits > 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:20.215670 [ 3849 ] {1c170e0a-106b-4005-9441-b60209ded3c5} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:20.482877 [ 2704 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:20.900683 [ 4101 ] {9a80b07e-7ed1-4728-9f6f-fe8c4592292e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57760) (comment: 00089_position_functions_with_non_constant_arg.sql) (in query: SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:20.902403 [ 4101 ] {9a80b07e-7ed1-4728-9f6f-fe8c4592292e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:21.483914 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:22.314061 [ 2658 ] {5b3eba44-0608-4754-b529-3f0cb438b53c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57686) (comment: 02400_memory_accounting_on_error.sql) (in query: SELECT * FROM system.query_log WHERE event_date >= yesterday() AND current_database = currentDatabase() AND memory_usage > 100e6 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a974a86 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:22.322127 [ 2658 ] {5b3eba44-0608-4754-b529-3f0cb438b53c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a974a86 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:22.485037 [ 3093 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:22.663976 [ 2658 ] {3f64743e-dbfd-4a14-96c9-88f642bd81cc} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51768) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:22.664518 [ 2658 ] {3f64743e-dbfd-4a14-96c9-88f642bd81cc} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:23.486756 [ 3081 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:23.554766 [ 4101 ] {8e798788-c864-45d1-ae78-c7b58cb91a1e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51786) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:23.557198 [ 4101 ] {8e798788-c864-45d1-ae78-c7b58cb91a1e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:24.489290 [ 3046 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:24.634596 [ 4101 ] {cba71927-64e8-40ad-97e1-333948c2766b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51880) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:24.638261 [ 4101 ] {cba71927-64e8-40ad-97e1-333948c2766b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:24.677867 [ 6440 ] {} test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:57:24.688638 [ 6440 ] {} DatabaseCatalog: Cannot drop table test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0). Will retry later.: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:24.708124 [ 2658 ] {d9e59241-ddc6-4b0d-a4f0-6cfc6370bd36} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51886) (comment: 00163_column_oriented_formats.sh) (in query: SELECT ClientEventTime from 00163_column_oriented), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:24.709807 [ 2658 ] {d9e59241-ddc6-4b0d-a4f0-6cfc6370bd36} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:25.490598 [ 2658 ] {92623d6d-f27d-4c55-b410-31d2d4345a69} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51908) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: OPTIMIZE TABLE test_02241 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e53e16 22. ./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) @ 0x0000000019e5ab6b 23. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 18:57:25.491630 [ 3019 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:25.502752 [ 2658 ] {92623d6d-f27d-4c55-b410-31d2d4345a69} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e53e16 22. ./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) @ 0x0000000019e5ab6b 23. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 18:57:25.674201 [ 4101 ] {91df5fce-3e3b-4711-8247-19b6127082d3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51922) (comment: 00148_monotonic_functions_and_index.sql) (in query: SELECT count() FROM test.hits WHERE abs(-CounterID) = 1731;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:25.677596 [ 4101 ] {91df5fce-3e3b-4711-8247-19b6127082d3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:25.875330 [ 4101 ] {92bd71e0-2d4e-459b-a625-804e34379cca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51938) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:25.877276 [ 4101 ] {92bd71e0-2d4e-459b-a625-804e34379cca} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.029295 [ 4101 ] {39189b7a-0471-416a-a2d8-270fefdde0d1} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51946) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE src DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.029845 [ 4101 ] {39189b7a-0471-416a-a2d8-270fefdde0d1} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.179882 [ 3274 ] {a6f615b8-a7d0-49f9-875e-5a1a8f2cf64f::all_5_5_0_6} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:26.179896 [ 3277 ] {a6f615b8-a7d0-49f9-875e-5a1a8f2cf64f::all_4_4_0_6} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:26.186563 [ 3277 ] {a6f615b8-a7d0-49f9-875e-5a1a8f2cf64f::all_4_4_0_6} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:26.186564 [ 3274 ] {a6f615b8-a7d0-49f9-875e-5a1a8f2cf64f::all_5_5_0_6} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:26.231059 [ 3268 ] {a6f615b8-a7d0-49f9-875e-5a1a8f2cf64f::all_5_5_0_6} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:26.233875 [ 3268 ] {a6f615b8-a7d0-49f9-875e-5a1a8f2cf64f::all_5_5_0_6} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:26.357479 [ 4101 ] {cb4b9c53-dc83-4ffb-90c7-d5bba168d2d6} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part 'all_4_4_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.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.10057.altinitytest (altinity build)) (from [::1]:51948) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: ALTER TABLE test_02241 UPDATE value = 'kek' WHERE key = 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019b98254 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019b9815c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e4a360 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b7c2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.358657 [ 4101 ] {cb4b9c53-dc83-4ffb-90c7-d5bba168d2d6} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part 'all_4_4_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019b98254 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019b9815c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e4a360 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b7c2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.493192 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:26.605057 [ 4101 ] {06a64fef-f9f1-467b-810c-fd71cbfef641} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51982) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.606580 [ 4101 ] {06a64fef-f9f1-467b-810c-fd71cbfef641} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.864515 [ 4101 ] {da08f4dd-b22c-449d-a1d2-87c4d1b2e9fe} executeQuery: Code: 57. DB::Exception: Table test_ulrqwad7.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00163_column_oriented_formats.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_ulrqwad7.`00163_column_oriented` UUID '615a8135-9df8-4e8c-94d0-84821f78495b' (`ClientEventTime` DateTime('Asia/Dubai'), `MobilePhoneModel` String, `ClientIP6` FixedString(16)) ENGINE = File(Arrow)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.870064 [ 4101 ] {da08f4dd-b22c-449d-a1d2-87c4d1b2e9fe} executeQuery: Code: 57. DB::Exception: Table test_ulrqwad7.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51992) (comment: 00163_column_oriented_formats.sh) (in query: CREATE TABLE 00163_column_oriented(ClientEventTime DateTime('Asia/Dubai'), MobilePhoneModel String, ClientIP6 FixedString(16)) ENGINE=File(Arrow)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:26.871619 [ 4101 ] {da08f4dd-b22c-449d-a1d2-87c4d1b2e9fe} TCPHandler: Code: 57. DB::Exception: Table test_ulrqwad7.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:27.423790 [ 4101 ] {e25b46ae-6c9e-4fc9-a8a3-db57be13b69e} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52014) (comment: 00163_column_oriented_formats.sh) (in query: INSERT INTO 00163_column_oriented SELECT ClientEventTime, MobilePhoneModel, ClientIP6 FROM test.hits ORDER BY ClientEventTime, MobilePhoneModel, ClientIP6 LIMIT 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000191d0141 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a787b7d 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d41ab4 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44ee1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:27.425351 [ 4101 ] {e25b46ae-6c9e-4fc9-a8a3-db57be13b69e} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000191d0141 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a787b7d 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d41ab4 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44ee1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:27.494648 [ 2973 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:28.496701 [ 2946 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:29.375077 [ 4101 ] {c196e0b1-4218-4b4a-903a-6c1d21021323} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52072) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:29.375810 [ 4101 ] {c196e0b1-4218-4b4a-903a-6c1d21021323} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:29.498160 [ 2984 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:29.694315 [ 5640 ] {} test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:57:29.695457 [ 5640 ] {} DatabaseCatalog: Cannot drop table test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0). 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:29.979321 [ 4101 ] {d2a8c7d7-c6e2-4c8f-9991-7fd6798ace04} executeQuery: Code: 57. DB::Exception: Table test_ulrqwad7.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00163_column_oriented_formats.sh) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_ulrqwad7.`00163_column_oriented` UUID 'c4099adf-0291-4c61-89e8-dd229cd7986f' (`ClientEventTime` DateTime('Asia/Dubai'), `MobilePhoneModel` String, `ClientIP6` FixedString(16)) ENGINE = File(ORC)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:29.983964 [ 4101 ] {d2a8c7d7-c6e2-4c8f-9991-7fd6798ace04} executeQuery: Code: 57. DB::Exception: Table test_ulrqwad7.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52088) (comment: 00163_column_oriented_formats.sh) (in query: CREATE TABLE 00163_column_oriented(ClientEventTime DateTime('Asia/Dubai'), MobilePhoneModel String, ClientIP6 FixedString(16)) ENGINE=File(ORC)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:29.985858 [ 4101 ] {d2a8c7d7-c6e2-4c8f-9991-7fd6798ace04} TCPHandler: Code: 57. DB::Exception: Table test_ulrqwad7.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:30.500146 [ 2916 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:30.510417 [ 2658 ] {dc1420bd-382a-4553-8ba8-45d8bbe64b10} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52002) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: INSERT INTO test_02241 SELECT number, toString(number) FROM numbers(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016490716 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016490385 9. ./contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x000000001657717a 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001655d45c 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::preFinalize() @ 0x000000001655c9c4 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 13. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000019c838a0 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000019c81822 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd14a0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 20. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 27. ./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*) @ 0x000000001a2e044a 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 2025.06.12 18:57:30.512145 [ 2658 ] {dc1420bd-382a-4553-8ba8-45d8bbe64b10} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016490716 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016490385 9. ./contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x000000001657717a 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001655d45c 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::preFinalize() @ 0x000000001655c9c4 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 13. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000019c838a0 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000019c81822 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd14a0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 20. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 27. ./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*) @ 0x000000001a2e044a 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 2025.06.12 18:57:30.534101 [ 4101 ] {f86c85ae-8b10-4fe2-b36f-5fd91073b121} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52090) (comment: 00163_column_oriented_formats.sh) (in query: INSERT INTO 00163_column_oriented SELECT ClientEventTime, MobilePhoneModel, ClientIP6 FROM test.hits ORDER BY ClientEventTime, MobilePhoneModel, ClientIP6 LIMIT 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000191d0141 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a787b7d 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d41ab4 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44ee1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:30.535183 [ 4101 ] {f86c85ae-8b10-4fe2-b36f-5fd91073b121} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000191d0141 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a787b7d 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d41ab4 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44ee1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:31.502360 [ 2886 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:32.504036 [ 2871 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:32.602752 [ 4203 ] {0a306b2a-e236-431d-9396-245c4087e7ec} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42566) (comment: 00163_column_oriented_formats.sh) (in query: DROP DATABASE IF EXISTS test_ulrqwad7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:32.605384 [ 4203 ] {0a306b2a-e236-431d-9396-245c4087e7ec} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:32.615301 [ 3921 ] {5ae1a661-e82e-4809-8f63-250a8fac569b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42578) (comment: 00163_column_oriented_formats.sh) (in query: DROP DATABASE IF EXISTS test_ulrqwad7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:32.616661 [ 3921 ] {5ae1a661-e82e-4809-8f63-250a8fac569b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:32.625397 [ 4203 ] {0c9aab59-741a-4755-bccb-0c302fd3802e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42588) (comment: 00163_column_oriented_formats.sh) (in query: DROP DATABASE IF EXISTS test_ulrqwad7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:32.626284 [ 4203 ] {0c9aab59-741a-4755-bccb-0c302fd3802e} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:32.635664 [ 3921 ] {300d205a-9d03-4cd3-a728-caec24ec07a7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42596) (comment: 00163_column_oriented_formats.sh) (in query: DROP DATABASE IF EXISTS test_ulrqwad7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:32.636942 [ 3921 ] {300d205a-9d03-4cd3-a728-caec24ec07a7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:32.643503 [ 4203 ] {b6288a4c-dfc6-45ed-ab97-9e93aec603f3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42602) (comment: 00163_column_oriented_formats.sh) (in query: DROP DATABASE IF EXISTS test_ulrqwad7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:32.644113 [ 4203 ] {b6288a4c-dfc6-45ed-ab97-9e93aec603f3} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:32.749559 [ 3921 ] {58ad36d6-0692-4c91-8273-4e40923155ef} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39088) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:32.750427 [ 3921 ] {58ad36d6-0692-4c91-8273-4e40923155ef} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:33.137678 [ 4203 ] {b5c7d60d-17ab-43a1-9386-5e8103ca206f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39096) (comment: 00166_explain_estimate.sql) (in query: EXPLAIN ESTIMATE SELECT count() FROM test.hits WHERE CounterID = 29103473;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:33.138747 [ 4203 ] {b5c7d60d-17ab-43a1-9386-5e8103ca206f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=737). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:33.504994 [ 2845 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:33.706006 [ 3748 ] {451f655c-237e-4e37-9a00-17556333a4b7} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39122) (comment: 00022_merge_prewhere.sql) (in query: DROP TABLE IF EXISTS test.merge_hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:33.707761 [ 3748 ] {451f655c-237e-4e37-9a00-17556333a4b7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:34.507361 [ 2833 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:34.515672 [ 8295 ] {} test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:57:34.520819 [ 8295 ] {} DatabaseCatalog: Cannot drop table test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0). Will retry later.: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:35.508249 [ 2807 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:36.092405 [ 3748 ] {73f5d140-c6a7-4aff-9a4e-d45eb8d4a46e} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39208) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:36.093132 [ 3748 ] {73f5d140-c6a7-4aff-9a4e-d45eb8d4a46e} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:36.283197 [ 3748 ] {7a1c1b35-7113-4100-8388-8ed5697756e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39210) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count() FROM (SELECT arrayJoin(cache_paths) AS cache_path, local_path, remote_path FROM system.remote_data_paths ) AS data_paths INNER JOIN system.filesystem_cache AS caches ON data_paths.cache_path = caches.cache_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:36.286148 [ 3748 ] {7a1c1b35-7113-4100-8388-8ed5697756e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:36.482355 [ 4203 ] {8e6d5953-481d-4790-a502-1a6ce880e0c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39112) (comment: 00165_jit_aggregate_functions.sql) (in query: SELECT 'Simple functions with non compilable function without key';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:36.483011 [ 4203 ] {8e6d5953-481d-4790-a502-1a6ce880e0c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=737). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:36.509555 [ 2793 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:37.510719 [ 2963 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:37.992165 [ 3748 ] {c3411355-a25b-4bb7-ac01-b497d07d2841} 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.10057.altinitytest (altinity build)) (from [::1]:39288) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:37.994321 [ 3748 ] {c3411355-a25b-4bb7-ac01-b497d07d2841} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:38.511424 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:38.779940 [ 3866 ] {2fd8d106-3cb2-4862-80e3-714203a0dcf1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51808) (comment: 00375_shard_group_uniq_array_of_string.sql) (in query: SELECT length(groupUniqArray(v)) FROM remote('127.0.0.{2,3,4,5}', currentDatabase(), 'group_uniq_str') GROUP BY id 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:38.781191 [ 3866 ] {2fd8d106-3cb2-4862-80e3-714203a0dcf1} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:39.429387 [ 3966 ] {28d0315d-171a-4870-a0f1-5fd5d241805d} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39386) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:39.430093 [ 3966 ] {28d0315d-171a-4870-a0f1-5fd5d241805d} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:39.512259 [ 2726 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:39.592884 [ 3966 ] {06e74c48-b57b-49e1-89d7-4f7cac385d3c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39398) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) size FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:39.594340 [ 3966 ] {06e74c48-b57b-49e1-89d7-4f7cac385d3c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:39.854641 [ 5643 ] {} test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 18:57:39.857527 [ 5643 ] {} DatabaseCatalog: Cannot drop table test_3.r1 (b49c9e90-640d-48ef-8885-5400ee5fa7e0). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=26, jobs=26). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:40.513018 [ 2711 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:40.672176 [ 5080 ] {adc78042-1d1a-4ec4-a5d6-dcce5007f1fd} ExternalDictionariesLoader: Could not load external dictionary 'a409dfad-4565-4c3c-80ca-6ea65ce90dc2', next update is scheduled at 2025-06-12 18:57:46: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=733). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb161ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000101d8583 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000101d7730 9. ./src/Dictionaries/PolygonDictionaryUtils.h:262: DB::GridRoot::makeCell(float, float, float, float, std::vector>, unsigned long)::'lambda'()::operator()() @ 0x00000000101d8cb6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101fb6c2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000101fa278 12. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000101fa17e 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101fb3ad 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:40.675070 [ 2656 ] {adc78042-1d1a-4ec4-a5d6-dcce5007f1fd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=733): while executing 'FUNCTION dictGet('dict_array'_String :: 2, 'value'_String :: 3, tuple(__table1.x, __table1.y) : 6) -> dictGet('dict_array'_String, 'value'_String, tuple(__table1.x, __table1.y)) UInt64 : 1'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51146) (comment: 01037_polygon_dicts_correctness_fast.sh) (in query: select 'dictGet', 'dict_array' as dict_name, tuple(x, y) as key, dictGet(dict_name, 'value', key) from points order by x, y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb161ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000101d8583 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000101d7730 9. ./src/Dictionaries/PolygonDictionaryUtils.h:262: DB::GridRoot::makeCell(float, float, float, float, std::vector>, unsigned long)::'lambda'()::operator()() @ 0x00000000101d8cb6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101fb6c2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000101fa278 12. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000101fa17e 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101fb3ad 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:40.676363 [ 2656 ] {adc78042-1d1a-4ec4-a5d6-dcce5007f1fd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=733): while executing 'FUNCTION dictGet('dict_array'_String :: 2, 'value'_String :: 3, tuple(__table1.x, __table1.y) : 6) -> dictGet('dict_array'_String, 'value'_String, tuple(__table1.x, __table1.y)) UInt64 : 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb161ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000101d8583 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000101d7730 9. ./src/Dictionaries/PolygonDictionaryUtils.h:262: DB::GridRoot::makeCell(float, float, float, float, std::vector>, unsigned long)::'lambda'()::operator()() @ 0x00000000101d8cb6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101fb6c2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000101fa278 12. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000101fa17e 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101fb3ad 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:41.047830 [ 5737 ] {4f4db664-fc48-4c11-bcdb-0ddb2438468a} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39538) (comment: 01037_polygon_dicts_correctness_fast.sh) (in query: DROP DICTIONARY IF EXISTS dict_array;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:41.048820 [ 5737 ] {4f4db664-fc48-4c11-bcdb-0ddb2438468a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:41.316109 [ 3826 ] {4c805b5d-16f1-42aa-ac5f-9b7d34e52b56} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39560) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:41.318423 [ 3826 ] {4c805b5d-16f1-42aa-ac5f-9b7d34e52b56} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:41.426807 [ 3966 ] {a3a4e92d-db29-4654-9d03-0ae0d891edb9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39550) (comment: 01921_datatype_date32.sql) (in query: select x1 from t1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:41.427306 [ 3966 ] {a3a4e92d-db29-4654-9d03-0ae0d891edb9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:41.489107 [ 3921 ] {d7112a6f-2315-411e-9dab-bfd958ea56ce} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42780) (comment: 01037_polygon_dicts_correctness_fast.sh) (in query: DROP DATABASE IF EXISTS test_af2orx7t ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:41.496861 [ 3921 ] {d7112a6f-2315-411e-9dab-bfd958ea56ce} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:41.513699 [ 2685 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:42.514435 [ 3168 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:42.778614 [ 3865 ] {8cdc89ce-0e7a-4308-a280-0c9decfb4a51} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56786) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:42.779074 [ 3865 ] {8cdc89ce-0e7a-4308-a280-0c9decfb4a51} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:43.583100 [ 3139 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:44.270004 [ 5738 ] {89b0e8f1-8686-4351-9aff-d3fbfd72e1e2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56896) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:44.271559 [ 5738 ] {89b0e8f1-8686-4351-9aff-d3fbfd72e1e2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:44.583917 [ 3119 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:45.133466 [ 5842 ] {356ea741-2b04-4495-9c7f-e5810a2d8dca} executeQuery: Code: 6. DB::Exception: Cannot parse string '2021-1-01 00:00:00' as DateTime: syntax error at position 10 (parsed just '2021-1-01 '): In scope SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '1')). (CANNOT_PARSE_TEXT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56950) (comment: 01750_parsing_exception.sh) (in query: SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '1'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776cec0 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&&) @ 0x0000000007958ac3 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:57:45.134782 [ 5842 ] {356ea741-2b04-4495-9c7f-e5810a2d8dca} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2021-1-01 00:00:00' as DateTime: syntax error at position 10 (parsed just '2021-1-01 '): In scope SELECT toDateTime(format('{}-{}-01 00:00:00', '2021', '1')). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776cec0 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&&) @ 0x0000000007958ac3 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:57:45.584864 [ 3103 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:45.585907 [ 3844 ] {101933df-86d2-4708-bbae-15e9e74b0860} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56954) (comment: 01948_dictionary_quoted_database_name.sql) (in query: DROP DICTIONARY `01945.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:45.587257 [ 3844 ] {101933df-86d2-4708-bbae-15e9e74b0860} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.138768 [ 5778 ] {5dff4efb-9d8c-4a13-a45d-8119b5e26333} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57010) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.139381 [ 5778 ] {5dff4efb-9d8c-4a13-a45d-8119b5e26333} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.421869 [ 5778 ] {6acffdd9-bb02-44f1-be8f-c08590cd9e92} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57026) (comment: 00005_filtering.sql) (in query: SELECT count() FROM test.hits WHERE AdvEngineID != 0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.422925 [ 5778 ] {6acffdd9-bb02-44f1-be8f-c08590cd9e92} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.442653 [ 3844 ] {cba7fac7-2d9a-44c0-858b-9784a9413754} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000008 */ CREATE TABLE test_pp3sz1x2.parsing_with_names UUID '7d92b41e-8590-46d3-a265-959dac5a185c' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.446945 [ 3844 ] {cba7fac7-2d9a-44c0-858b-9784a9413754} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57042) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.447889 [ 3844 ] {cba7fac7-2d9a-44c0-858b-9784a9413754} TCPHandler: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.465368 [ 5842 ] {35d2cf81-e9f0-4bf2-aeb7-60ae1e729d14} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56994) (comment: 02346_position_countsubstrings_zero_byte.sql) (in query: select position(haystack, pattern) from tab where id = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 2025.06.12 18:57:46.466849 [ 5842 ] {35d2cf81-e9f0-4bf2-aeb7-60ae1e729d14} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 2025.06.12 18:57:46.565078 [ 5843 ] {7bc84a08-feae-47c6-ac4b-7d51526859db} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57050) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.566016 [ 5843 ] {7bc84a08-feae-47c6-ac4b-7d51526859db} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.585825 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:46.924333 [ 3961 ] {45bc3659-d3c0-4f01-9d42-e708dc2c89b7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57088) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:46.924841 [ 3961 ] {45bc3659-d3c0-4f01-9d42-e708dc2c89b7} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:47.587495 [ 3063 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:47.710296 [ 4252 ] {f068eda5-8759-422d-80fc-6e0e821fb932} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57126) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:47.711071 [ 4252 ] {f068eda5-8759-422d-80fc-6e0e821fb932} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:48.406405 [ 4083 ] {3245c342-b0c8-4bef-9c95-13eb35356726} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195e521c 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000195e4e70 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x00000000195e4c97 11. ./src/Storages/IStorage.h:594: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bf68 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:48.478801 [ 5843 ] {354b4301-543d-4961-90da-29bcce78057f} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000010 */ CREATE TABLE test_pp3sz1x2.parsing_with_names UUID 'e75f572d-bfb8-49d1-8cb4-d735adbb68c7' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:48.484070 [ 5843 ] {354b4301-543d-4961-90da-29bcce78057f} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57164) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:48.486967 [ 5843 ] {354b4301-543d-4961-90da-29bcce78057f} TCPHandler: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:48.589557 [ 3197 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:48.764022 [ 2677 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195e521c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1088: DB::StorageBuffer::backgroundFlush() @ 0x00000000195ea502 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195eb7a2 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:48.977830 [ 4083 ] {b86f1afe-ab7b-413a-9d8e-aaf7e3a9ef0d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57150) (comment: 00061_storage_buffer.sql) (in query: DROP TABLE test.hits_buffer;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:48.980731 [ 4083 ] {b86f1afe-ab7b-413a-9d8e-aaf7e3a9ef0d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:49.591104 [ 3014 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:50.128814 [ 4083 ] {8084e768-6b24-4150-b9b1-5f1b43578e92} 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.10057.altinitytest (altinity build)) (from [::1]:57240) (comment: 00178_quantile_ddsketch.sql) (in query: SELECT CounterID AS k, round(quantileDD(0.01, 0.5)(ResolutionWidth), 2) FROM test.hits GROUP BY k ORDER BY count() DESC, CounterID LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:50.131349 [ 4083 ] {8084e768-6b24-4150-b9b1-5f1b43578e92} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:50.592629 [ 2993 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:50.598983 [ 3961 ] {1c3c0082-b5ed-4cd6-9dbe-62b7a2d110b0} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000012 */ CREATE TABLE test_pp3sz1x2.parsing_with_names UUID '7b163ee1-ff4a-461b-8506-0f238e31c973' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:50.604933 [ 4083 ] {d23f211c-7712-48c0-a051-0c0206effd36} 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.10057.altinitytest (altinity build)) (from [::1]:57256) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174d629c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749bddf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:50.605419 [ 3961 ] {1c3c0082-b5ed-4cd6-9dbe-62b7a2d110b0} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57266) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:50.606059 [ 4083 ] {d23f211c-7712-48c0-a051-0c0206effd36} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174d629c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749bddf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:50.606623 [ 3961 ] {1c3c0082-b5ed-4cd6-9dbe-62b7a2d110b0} TCPHandler: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:50.650071 [ 4252 ] {1290a3be-206b-4791-af78-6b243987df92} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57236) (comment: 02578_parameterized_rename_queries.sql) (in query: DROP DATABASE `02661_db1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:50.653950 [ 4252 ] {1290a3be-206b-4791-af78-6b243987df92} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:51.111911 [ 3849 ] {7f2fa293-d9ee-46bb-84e7-79e16c56a0c9} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57320) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:51.113988 [ 3849 ] {7f2fa293-d9ee-46bb-84e7-79e16c56a0c9} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:51.430840 [ 3967 ] {7c4f4348-0b69-4f5c-afc0-d2d58c994b03} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57332) (comment: 00140_rename.sql) (in query: SELECT count() FROM test.hits WHERE CounterID = 732797;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:51.431701 [ 3967 ] {7c4f4348-0b69-4f5c-afc0-d2d58c994b03} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=741). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:51.594658 [ 2968 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:51.764735 [ 4083 ] {38336e97-8e36-4295-9870-fb4fbb902a00} executeQuery: Code: 57. DB::Exception: Table test_3.geo already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57292) (comment: 01300_svg.sql) (in query: CREATE TABLE geo (p Array(Tuple(Float64, Float64)), s String, id 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:51.766220 [ 4083 ] {38336e97-8e36-4295-9870-fb4fbb902a00} TCPHandler: Code: 57. DB::Exception: Table test_3.geo already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:51.871230 [ 4083 ] {cb530a36-4113-45d9-81fb-106690baf56c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57362) (comment: 00078_group_by_arrays.sql) (in query: SELECT GoalsReached AS k, count() AS c FROM test.hits GROUP BY k ORDER BY c DESC LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:51.875947 [ 4083 ] {cb530a36-4113-45d9-81fb-106690baf56c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:52.597852 [ 2953 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:52.659967 [ 4083 ] {6219754a-6b74-4f6c-b9bc-4ee032a0405b} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000014 */ CREATE TABLE test_pp3sz1x2.parsing_with_names UUID '496fe0a3-c15e-4816-bcc5-dae4f116839f' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:52.670761 [ 4083 ] {6219754a-6b74-4f6c-b9bc-4ee032a0405b} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51856) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:52.674760 [ 4083 ] {6219754a-6b74-4f6c-b9bc-4ee032a0405b} TCPHandler: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:52.718684 [ 3961 ] {8e70dad8-4eab-4227-bbe0-4942033ee697} executeQuery: Code: 117. DB::Exception: Incorrect size (0) in groupBitmap.: In scope SELECT CAST('\0', 'AggregateFunction(groupBitmap, UInt32)'). (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51844) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x01\x00'::AggregateFunction(groupBitmap, UInt32);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:128: _ZN2DB25RoaringBitmapWithSmallSetIjLDu32EE4readERNS_10ReadBufferE @ 0x0000000015915eeb 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:61: DB::(anonymous namespace)::AggregateFunctionBitmap>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000158abbc5 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 18:57:52.719593 [ 3961 ] {8e70dad8-4eab-4227-bbe0-4942033ee697} TCPHandler: Code: 117. DB::Exception: Incorrect size (0) in groupBitmap.: In scope SELECT CAST('\0', 'AggregateFunction(groupBitmap, UInt32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:128: _ZN2DB25RoaringBitmapWithSmallSetIjLDu32EE4readERNS_10ReadBufferE @ 0x0000000015915eeb 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:61: DB::(anonymous namespace)::AggregateFunctionBitmap>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000158abbc5 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 18:57:53.079376 [ 3961 ] {cb15339e-d963-4369-8497-c0cd04135b36} executeQuery: std::exception. Code: 1001, type: std::runtime_error, e.what() = ran out of bytes (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51844) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x01\x01\x01'::AggregateFunction(groupBitmap, UInt64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(char const*) @ 0x00000000217af03d 1. ./contrib/croaring/cpp/roaring64map.hh:1186: roaring::Roaring64Map::readSafe(char const*, unsigned long) @ 0x0000000015917023 2. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:0: _ZN2DB25RoaringBitmapWithSmallSetImLDu32EE4readERNS_10ReadBufferE @ 0x0000000015916901 3. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:61: DB::(anonymous namespace)::AggregateFunctionBitmap>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000158ae065 4. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 18:57:53.080610 [ 3961 ] {cb15339e-d963-4369-8497-c0cd04135b36} TCPHandler: Code: 1001. DB::Exception: std::runtime_error: ran out of bytes. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(char const*) @ 0x00000000217af03d 1. ./contrib/croaring/cpp/roaring64map.hh:1186: roaring::Roaring64Map::readSafe(char const*, unsigned long) @ 0x0000000015917023 2. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:0: _ZN2DB25RoaringBitmapWithSmallSetImLDu32EE4readERNS_10ReadBufferE @ 0x0000000015916901 3. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:61: DB::(anonymous namespace)::AggregateFunctionBitmap>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000158ae065 4. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 18:57:53.187518 [ 3849 ] {5836b5ff-f284-42bd-88b3-9227b2f48a4f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51910) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:53.190142 [ 3849 ] {5836b5ff-f284-42bd-88b3-9227b2f48a4f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=741). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:53.423518 [ 3961 ] {73cea61d-d0ef-4502-ad3d-1892d71482f5} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 2. Bytes expected: 32.: In scope SELECT CAST('\0\r', 'AggregateFunction(topK, UInt256)'). (CANNOT_READ_ALL_DATA) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51844) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x02\x00\x0d'::AggregateFunction(topK, UInt256);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66fad 5. ./src/Common/SpaceSaving.h:113: DB::SpaceSaving, HashCRC32>>::read(DB::ReadBuffer&) @ 0x00000000157eb9ac 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:145: DB::(anonymous namespace)::AggregateFunctionTopK, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000001577d5ce 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 29. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 2025.06.12 18:57:53.424751 [ 3961 ] {73cea61d-d0ef-4502-ad3d-1892d71482f5} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 2. Bytes expected: 32.: In scope SELECT CAST('\0\r', 'AggregateFunction(topK, UInt256)'). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66fad 5. ./src/Common/SpaceSaving.h:113: DB::SpaceSaving, HashCRC32>>::read(DB::ReadBuffer&) @ 0x00000000157eb9ac 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:145: DB::(anonymous namespace)::AggregateFunctionTopK, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000001577d5ce 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 29. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 2025.06.12 18:57:53.507792 [ 4083 ] {4b60036d-9158-43af-a8b3-96b26dbf4bfc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51876) (comment: 01043_geo_distance.sql) (in query: SELECT greatCircleDistance(0., 0., 0., 90.);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:53.508674 [ 4083 ] {4b60036d-9158-43af-a8b3-96b26dbf4bfc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=741). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:53.604498 [ 2942 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:53.812212 [ 3961 ] {45f61a53-e920-47d7-a299-2ace2fb6c754} executeQuery: Code: 128. DB::Exception: The size of serialized hash table is suspiciously large: 4502748553425166142: In scope SELECT CAST(unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300'), 'AggregateFunction(minDistinct, Int8)'). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51844) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300')::AggregateFunction(minDistinct, Int8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000821f800 4. ./src/Common/HashTable/HashTable.h:1334: HashTable<_BitInt(8), HashTableCell, HashTableNoState>, HashTableNoState, HashTableGrower<4ul>, AllocatorWithStackMemory, 16ul, 1ul>>::read(DB::ReadBuffer&) @ 0x0000000013ee9a4f 5. ./src/AggregateFunctions/Combinators/AggregateFunctionDistinct.h:198: DB::AggregateFunctionDistinct>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000015d6bfa1 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 18:57:53.814216 [ 3961 ] {45f61a53-e920-47d7-a299-2ace2fb6c754} TCPHandler: Code: 128. DB::Exception: The size of serialized hash table is suspiciously large: 4502748553425166142: In scope SELECT CAST(unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300'), 'AggregateFunction(minDistinct, Int8)'). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000821f800 4. ./src/Common/HashTable/HashTable.h:1334: HashTable<_BitInt(8), HashTableCell, HashTableNoState>, HashTableNoState, HashTableGrower<4ul>, AllocatorWithStackMemory, 16ul, 1ul>>::read(DB::ReadBuffer&) @ 0x0000000013ee9a4f 5. ./src/AggregateFunctions/Combinators/AggregateFunctionDistinct.h:198: DB::AggregateFunctionDistinct>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000015d6bfa1 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 18:57:54.031386 [ 3961 ] {b51c4dd1-d250-4f13-8e5f-8b28e336d4a0} executeQuery: Code: 117. DB::Exception: The number of elements 2816 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51844) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300')::AggregateFunction(quantileTiming, Int32);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x00000000144eb6e6 4. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x00000000144eb35f 5. ./src/AggregateFunctions/QuantileTiming.h:713: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x00000000145098e3 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTiming, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000145066e1 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 29. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 2025.06.12 18:57:54.035236 [ 3961 ] {b51c4dd1-d250-4f13-8e5f-8b28e336d4a0} TCPHandler: Code: 117. DB::Exception: The number of elements 2816 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x00000000144eb6e6 4. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x00000000144eb35f 5. ./src/AggregateFunctions/QuantileTiming.h:713: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x00000000145098e3 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTiming, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000145066e1 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 29. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 2025.06.12 18:57:54.047710 [ 3961 ] {4957781c-cb9e-4b2f-a8b2-a572cd0432a0} executeQuery: Code: 117. DB::Exception: The number of elements 256 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('010001'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51844) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('010001')::AggregateFunction(quantileTiming, Int32);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x00000000144eb6e6 4. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x00000000144eb35f 5. ./src/AggregateFunctions/QuantileTiming.h:713: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x00000000145098e3 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTiming, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000145066e1 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 29. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 2025.06.12 18:57:54.049424 [ 3961 ] {4957781c-cb9e-4b2f-a8b2-a572cd0432a0} TCPHandler: Code: 117. DB::Exception: The number of elements 256 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('010001'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x00000000144eb6e6 4. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x00000000144eb35f 5. ./src/AggregateFunctions/QuantileTiming.h:713: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x00000000145098e3 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTiming, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000145066e1 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 29. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 2025.06.12 18:57:54.361152 [ 3961 ] {2cb0b612-3c28-4196-8f0f-ea118af306b7} executeQuery: Code: 128. DB::Exception: Suspiciously large array size (8753160913407246346) in -ForEach aggregate function: In scope SELECT CAST(unhex('0a00797979797979797979790a0a6e'), 'AggregateFunction(minForEach, Ring)'). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51844) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('0a00797979797979797979790a0a6e')::AggregateFunction(minForEach, Ring);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000821f800 4. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:74: DB::AggregateFunctionForEach::ensureAggregateData(char*, unsigned long, DB::Arena&) const @ 0x0000000015d90b7c 5. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:0: DB::AggregateFunctionForEach::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000015d8ef11 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 18:57:54.361906 [ 3961 ] {2cb0b612-3c28-4196-8f0f-ea118af306b7} TCPHandler: Code: 128. DB::Exception: Suspiciously large array size (8753160913407246346) in -ForEach aggregate function: In scope SELECT CAST(unhex('0a00797979797979797979790a0a6e'), 'AggregateFunction(minForEach, Ring)'). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000821f800 4. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:74: DB::AggregateFunctionForEach::ensureAggregateData(char*, unsigned long, DB::Arena&) const @ 0x0000000015d90b7c 5. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:0: DB::AggregateFunctionForEach::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000015d8ef11 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000016f59c78 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016f59f9f 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c546 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000079bb1ac 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 18:57:54.490413 [ 4083 ] {08da95ec-1aa3-4049-b96d-1ffd1d4d57a4} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51982) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:54.491502 [ 4083 ] {08da95ec-1aa3-4049-b96d-1ffd1d4d57a4} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:54.605752 [ 2898 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:55.163729 [ 3866 ] {1fcf4292-304a-4748-814c-8d3267b307a1} executeQuery: Code: 46. DB::Exception: User-defined object '02101_test_function' doesn't exist: while removing user defined function `02101_test_function`. (UNKNOWN_FUNCTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52004) (comment: 02101_sql_user_defined_functions_drop_if_exists.sql) (in query: DROP FUNCTION 02101_test_function;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLObjectsStorageBase.cpp:134: DB::UserDefinedSQLObjectsStorageBase::removeObject(std::shared_ptr const&, DB::UserDefinedSQLObjectType, String const&, bool) @ 0x000000001aa585a6 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:164: DB::UserDefinedSQLFunctionFactory::unregisterFunction(std::shared_ptr const&, String const&, bool) @ 0x000000001aa413b7 6. ./src/QueryPipeline/BlockIO.h:14: DB::InterpreterDropFunctionQuery::execute() @ 0x00000000182b36f3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:55.164499 [ 3866 ] {1fcf4292-304a-4748-814c-8d3267b307a1} TCPHandler: Code: 46. DB::Exception: User-defined object '02101_test_function' doesn't exist: while removing user defined function `02101_test_function`. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLObjectsStorageBase.cpp:134: DB::UserDefinedSQLObjectsStorageBase::removeObject(std::shared_ptr const&, DB::UserDefinedSQLObjectType, String const&, bool) @ 0x000000001aa585a6 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:164: DB::UserDefinedSQLFunctionFactory::unregisterFunction(std::shared_ptr const&, String const&, bool) @ 0x000000001aa413b7 6. ./src/QueryPipeline/BlockIO.h:14: DB::InterpreterDropFunctionQuery::execute() @ 0x00000000182b36f3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:55.607373 [ 2895 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:56.620502 [ 2842 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:57.268464 [ 3866 ] {258405e8-2f89-42c2-b7ac-238c3a5b02f4} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000018 */ CREATE TABLE test_pp3sz1x2.parsing_with_names UUID '385d041c-07a7-45c6-82f8-7dae5e13f2a9' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:57.278925 [ 3866 ] {258405e8-2f89-42c2-b7ac-238c3a5b02f4} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52164) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:57.280930 [ 3866 ] {258405e8-2f89-42c2-b7ac-238c3a5b02f4} TCPHandler: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:57.624699 [ 2808 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:57.840275 [ 3866 ] {5f761e37-b648-4e43-99e5-0b048137d01c} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52222) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:57.841038 [ 3866 ] {5f761e37-b648-4e43-99e5-0b048137d01c} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:57.901058 [ 2656 ] {mysql:0:817baf46-a9c2-4691-9edb-661dfa1836ad} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'table_that_does_not_exist' in scope SELECT * FROM table_that_does_not_exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45412) (in query: select * from table_that_does_not_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 15. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a173ecb 16. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a16f341 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:57.903162 [ 2656 ] {} MySQLHandler: MySQLHandler: Cannot read packet: : Code: 60. DB::Exception: Unknown table expression identifier 'table_that_does_not_exist' in scope SELECT * FROM table_that_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 15. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a173ecb 16. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a16f341 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:58.111841 [ 2656 ] {mysql:0:99537ccf-43ab-407d-a0bf-f552ba09ac3c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(__table1.number :: 1) -> throwIf(__table1.number) UInt8 : 0'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45412) (in query: select throwIf(number) from numbers(2) settings max_block_size=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3dab80 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821b8bc 19. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a173ecb 20. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a16f341 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:58.114129 [ 2656 ] {} MySQLHandler: MySQLHandler: Cannot read packet: : Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(__table1.number :: 1) -> throwIf(__table1.number) UInt8 : 0'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3dab80 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821b8bc 19. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a173ecb 20. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a16f341 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:58.189612 [ 2656 ] {mysql:0:cfe3ae20-3d12-4a9a-be64-e166b30881a4} executeQuery: Code: 1. DB::Exception: MySQL protocol does not support custom output formats. (UNSUPPORTED_METHOD) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45412) (in query: select * from system.one format TSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Server/MySQLHandler.cpp:507: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, DB::QueryResultDetails const&) @ 0x000000001a17951c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001821b84e 6. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a173ecb 7. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a16f341 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:58.191199 [ 2656 ] {} MySQLHandler: MySQLHandler: Cannot read packet: : Code: 1. DB::Exception: MySQL protocol does not support custom output formats. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Server/MySQLHandler.cpp:507: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, DB::QueryResultDetails const&) @ 0x000000001a17951c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001821b84e 6. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a173ecb 7. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a16f341 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:58.196496 [ 2656 ] {mysql:0:2deb2371-de72-4c0b-8b41-119097fc3cad} executeQuery: Code: 1. DB::Exception: MySQL protocol does not support custom output formats. (UNSUPPORTED_METHOD) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45412) (in query: select * from system.one 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Server/MySQLHandler.cpp:507: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, DB::QueryResultDetails const&) @ 0x000000001a17951c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001821b84e 6. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a173ecb 7. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a16f341 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:58.198602 [ 2656 ] {} MySQLHandler: MySQLHandler: Cannot read packet: : Code: 1. DB::Exception: MySQL protocol does not support custom output formats. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Server/MySQLHandler.cpp:507: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, DB::QueryResultDetails const&) @ 0x000000001a17951c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001821b84e 6. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a173ecb 7. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a16f341 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:58.628129 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:57:59.414342 [ 3866 ] {082e69ff-9dc2-4a90-9846-c96a4229239a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52256) (comment: 00908_bloom_filter_index.sh) (in query: SELECT * FROM bloom_filter_idx WHERE s LIKE '%database%' AND s LIKE '%ClickHouse%' ORDER BY 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:59.415966 [ 3866 ] {082e69ff-9dc2-4a90-9846-c96a4229239a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:59.473965 [ 3966 ] {7f941080-4a91-40f8-ace6-6a0af4c7cd8d} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000020 */ CREATE TABLE test_pp3sz1x2.parsing_with_names UUID 'efbc25d5-4481-40e4-b439-2650c5398fc7' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:59.477802 [ 3966 ] {7f941080-4a91-40f8-ace6-6a0af4c7cd8d} executeQuery: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52262) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:59.479075 [ 3966 ] {7f941080-4a91-40f8-ace6-6a0af4c7cd8d} TCPHandler: Code: 57. DB::Exception: Table test_pp3sz1x2.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:57:59.629094 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:00.133480 [ 4203 ] {1445535d-5583-4758-bc55-9983f123a8f6} DynamicQueryHandler: Code: 271. DB::Exception: Too large uncompressed size: 4294967295. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000001632cbe0 4. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:0: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000016d75057 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000016dc0590 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:318: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x0000000016d5c78d 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:13: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x0000000016d5a6b6 8. DB::ReadBuffer::next() @ 0x0000000007b3417b 9. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000016590efb 10. DB::ReadBuffer::next() @ 0x0000000007b3417b 11. ./src/IO/ConcatReadBuffer.h:0: DB::ConcatReadBuffer::nextImpl() @ 0x000000001755f2d7 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821aa08 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:00.347617 [ 4203 ] {fde5ffe3-4343-48af-a235-6231e3b9d1fb} DynamicQueryHandler: Code: 246. DB::Exception: Wrong data for compression codec NONE: source_size (278) != uncompressed_size (33686018). (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int&) @ 0x00000000135d6626 4. ./build_docker/./src/Compression/CompressionCodecNone.cpp:33: DB::CompressionCodecNone::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000016d6e7d0 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000016dc0590 6. ./src/Common/PODArray.h:161: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000016d74d38 7. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000016dc0590 8. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:318: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x0000000016d5c78d 9. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:13: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x0000000016d5a6b6 10. DB::ReadBuffer::next() @ 0x0000000007b3417b 11. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000016590efb 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./src/IO/ConcatReadBuffer.h:0: DB::ConcatReadBuffer::nextImpl() @ 0x000000001755f2d7 14. DB::ReadBuffer::next() @ 0x0000000007b3417b 15. ./src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821aa08 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:00.630691 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:01.225873 [ 4203 ] {db12a587-eb09-4997-a04d-970f84b27099} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37322) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: DROP DATABASE IF EXISTS test_pp3sz1x2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.229691 [ 4203 ] {db12a587-eb09-4997-a04d-970f84b27099} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:01.243008 [ 5737 ] {ca45bfc4-5633-4b76-8688-8c023d7b0c3a} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52376) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.245160 [ 5737 ] {ca45bfc4-5633-4b76-8688-8c023d7b0c3a} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.245659 [ 3866 ] {f96656c1-115f-4cf6-8b89-144f0be2e46c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37332) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: DROP DATABASE IF EXISTS test_pp3sz1x2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.246923 [ 3866 ] {f96656c1-115f-4cf6-8b89-144f0be2e46c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:01.290373 [ 3921 ] {8d71d70b-cb1d-4889-b0f1-fda47e552838} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37348) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: DROP DATABASE IF EXISTS test_pp3sz1x2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.291808 [ 3921 ] {8d71d70b-cb1d-4889-b0f1-fda47e552838} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:01.301444 [ 3966 ] {0b20ad70-806e-4ad3-9c96-fca72c662db1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37356) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: DROP DATABASE IF EXISTS test_pp3sz1x2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.303332 [ 3966 ] {0b20ad70-806e-4ad3-9c96-fca72c662db1} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:01.312341 [ 3921 ] {740575b3-cda9-4530-9d60-e1e48f681d9a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37366) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: DROP DATABASE IF EXISTS test_pp3sz1x2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.313579 [ 3921 ] {740575b3-cda9-4530-9d60-e1e48f681d9a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:01.344238 [ 5737 ] {ef1df0c0-c0d9-4a8c-ba76-2e3b61c2e018} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52402) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count() FROM test_02241), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.346492 [ 5737 ] {ef1df0c0-c0d9-4a8c-ba76-2e3b61c2e018} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:01.634386 [ 2713 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:02.543120 [ 3966 ] {9fd1171f-7a36-4714-93b1-741cedbf3865} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52408) (comment: 00908_bloom_filter_index.sh) (in query: SELECT * FROM bloom_filter_idx WHERE s LIKE '%базами данных%' AND s LIKE '%ClickHouse%' ORDER BY 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019b1a9f9 11. ./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) @ 0x0000000019af448e 12. ./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 @ 0x0000000019af1f40 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:731: 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) @ 0x0000000019aeec7b 14. ./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) @ 0x000000001a934995 15. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 16. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 17. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 18. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 19. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:02.586823 [ 3966 ] {9fd1171f-7a36-4714-93b1-741cedbf3865} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019b1a9f9 11. ./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) @ 0x0000000019af448e 12. ./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 @ 0x0000000019af1f40 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:731: 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) @ 0x0000000019aeec7b 14. ./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) @ 0x000000001a934995 15. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 16. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 17. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 18. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 19. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:02.617598 [ 3921 ] {f848aa8e-c98f-476f-aed0-f1cd8e26f085} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=777). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38844) (comment: 00181_cross_join_compression.sql) (in query: CREATE VIEW unit 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:02.626666 [ 3921 ] {f848aa8e-c98f-476f-aed0-f1cd8e26f085} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=777). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:02.642643 [ 2687 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:03.645341 [ 3174 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:04.586312 [ 3921 ] {58761ba0-30b0-4059-8a5a-7743c179258a} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38962) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO dst_r1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:04.586980 [ 3921 ] {58761ba0-30b0-4059-8a5a-7743c179258a} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:04.646437 [ 3194 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:05.154556 [ 3826 ] {20186dcd-263d-4c2b-8db8-a628b8df1969} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39026) (comment: 00908_bloom_filter_index.sh) (in query: SELECT * FROM bloom_filter_idx WHERE s LIKE '%%
_%_%_
%%' ORDER BY k 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:05.157477 [ 3826 ] {20186dcd-263d-4c2b-8db8-a628b8df1969} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:05.649157 [ 3118 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:06.170090 [ 3844 ] {0d90e77a-1d36-43b4-9cd3-aa3fd54a00c6} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54514) (comment: 00181_cross_join_compression.sql) (in query: DROP DATABASE IF EXISTS test_0p363qwg ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 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>>>&) @ 0x0000000017c6e9aa 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:06.239806 [ 3844 ] {0d90e77a-1d36-43b4-9cd3-aa3fd54a00c6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 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>>>&) @ 0x0000000017c6e9aa 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:06.295328 [ 3921 ] {85878bb9-29aa-406f-8403-5707ce0afa37} 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.10057.altinitytest (altinity build)) (from [::1]:39104) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:06.297482 [ 3921 ] {85878bb9-29aa-406f-8403-5707ce0afa37} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:06.370405 [ 5778 ] {56736be8-690d-4083-8660-2424e3ddc4bc} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39126) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:06.371030 [ 5778 ] {56736be8-690d-4083-8660-2424e3ddc4bc} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:06.652758 [ 3094 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:07.156239 [ 5778 ] {7ff02418-6283-454b-84c6-f2bc9a48b911} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=756). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39232) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count() FROM (SELECT arrayJoin(cache_paths) AS cache_path, local_path, remote_path FROM system.remote_data_paths ) AS data_paths INNER JOIN system.filesystem_cache AS caches ON data_paths.cache_path = caches.cache_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:07.158742 [ 5778 ] {7ff02418-6283-454b-84c6-f2bc9a48b911} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=756). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:07.654424 [ 3052 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:08.655619 [ 3016 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:09.085562 [ 5779 ] {a17d2e42-579d-4bb8-9361-e8ed7f22f12c} executeQuery: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_7mvqnhdy.parsing_with_names UUID 'fe0b6d8b-5362-4041-8f43-98040024e7cf' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:09.089320 [ 5779 ] {a17d2e42-579d-4bb8-9361-e8ed7f22f12c} executeQuery: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39382) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:09.090698 [ 5779 ] {a17d2e42-579d-4bb8-9361-e8ed7f22f12c} TCPHandler: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:09.107235 [ 3844 ] {353b1bf4-f5c1-4a19-a0f8-508fe53bffa7} 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.10057.altinitytest (altinity build)) (from [::1]:39368) (comment: 00081_group_by_without_key_and_totals.sql) (in query: SELECT count() AS c FROM test.hits WHERE CounterID = 1704509 WITH TOTALS SETTINGS totals_mode = 'after_having_exclusive', max_rows_to_group_by = 100000, group_by_overflow_mode = 'any';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:09.108315 [ 3844 ] {353b1bf4-f5c1-4a19-a0f8-508fe53bffa7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:09.656679 [ 3021 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:09.708334 [ 3844 ] {7df760da-63a1-4dfb-9fdd-eb0475fbdda6} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39468) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:09.708843 [ 3844 ] {7df760da-63a1-4dfb-9fdd-eb0475fbdda6} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:10.657347 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:10.790987 [ 5779 ] {df856995-ba42-4e19-aee3-77dfb24d2960} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=755). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39558) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 9627212;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:10.791987 [ 5779 ] {df856995-ba42-4e19-aee3-77dfb24d2960} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:11.192955 [ 5779 ] {89b82cff-4961-465f-b57f-88846598f6db} executeQuery: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000006 */ CREATE TABLE test_7mvqnhdy.parsing_with_names UUID 'a6a2708d-8bdb-4964-8a04-65ce59dcb9fa' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:11.198091 [ 5779 ] {89b82cff-4961-465f-b57f-88846598f6db} executeQuery: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39614) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:11.199675 [ 5779 ] {89b82cff-4961-465f-b57f-88846598f6db} TCPHandler: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:11.658211 [ 2950 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:12.598978 [ 4252 ] {de9fb334-74ac-4afb-96c3-26a026fe0993} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35276) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:12.600581 [ 4252 ] {de9fb334-74ac-4afb-96c3-26a026fe0993} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:12.659248 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:13.064879 [ 5843 ] {466100bd-651c-421c-814e-cc3f9c1210a9} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35326) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:13.065463 [ 5843 ] {466100bd-651c-421c-814e-cc3f9c1210a9} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:13.228165 [ 3849 ] {ec289852-09ee-471c-b5ba-7c7194c2c023} executeQuery: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000008 */ CREATE TABLE test_7mvqnhdy.parsing_with_names UUID 'b9d9fbdb-e52b-476a-898b-3678a1d84629' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:13.231789 [ 3849 ] {ec289852-09ee-471c-b5ba-7c7194c2c023} executeQuery: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35370) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:13.233745 [ 3849 ] {ec289852-09ee-471c-b5ba-7c7194c2c023} TCPHandler: Code: 57. DB::Exception: Table test_7mvqnhdy.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:13.519213 [ 5843 ] {fb458e4a-7c4f-4bee-997c-1c9ab72c4436} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35374) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT count(), sum(size) FROM system.filesystem_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:13.521370 [ 5843 ] {fb458e4a-7c4f-4bee-997c-1c9ab72c4436} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:13.660073 [ 2918 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:13.758532 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {73eb3115-ba28-4354-b9cc-92eaf7cc4118::202506_1_16_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:13.804344 [ 3281 ] {fd26f944-b325-46f6-8698-2c4e90fa04e6::all_1_5_1_6} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:13.804883 [ 3281 ] {fd26f944-b325-46f6-8698-2c4e90fa04e6::all_1_5_1_6} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:13.805792 [ 3849 ] {0b8cdeb0-8b28-4b29-b5c9-6c0a5ba5c7b7} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part 'all_1_5_1' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.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.10057.altinitytest (altinity build)) (from [::1]:35432) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: ALTER TABLE test_02241 UPDATE value = 'kek' WHERE key = 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019b98254 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019b9815c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e4a360 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b7c2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:13.807369 [ 3849 ] {0b8cdeb0-8b28-4b29-b5c9-6c0a5ba5c7b7} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part 'all_1_5_1' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019b98254 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019b9815c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e4a360 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b7c2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:14.332155 [ 3961 ] {add55d27-6a87-45dd-bf47-ef2dad369380} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35468) (comment: 00908_bloom_filter_index.sh) (in query: SELECT * FROM bloom_filter_idx3 WHERE lower(s) LIKE '%(dbms)%' ORDER BY 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5ae03 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 16. DB::ReadBuffer::next() @ 0x0000000007b3417b 17. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::MergeTreeIndexGranuleBloomFilterText::deserializeBinary(DB::ReadBuffer&, unsigned char) @ 0x0000000019b3c952 19. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:90: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000019b1b86b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1386: 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) @ 0x0000000019af4890 21. ./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 @ 0x0000000019af1f40 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:731: 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) @ 0x0000000019aeec7b 23. ./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) @ 0x000000001a934995 24. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 25. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 26. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 27. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 28. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 2025.06.12 18:58:14.333471 [ 3961 ] {add55d27-6a87-45dd-bf47-ef2dad369380} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5ae03 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 16. DB::ReadBuffer::next() @ 0x0000000007b3417b 17. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::MergeTreeIndexGranuleBloomFilterText::deserializeBinary(DB::ReadBuffer&, unsigned char) @ 0x0000000019b3c952 19. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:90: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000019b1b86b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1386: 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) @ 0x0000000019af4890 21. ./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 @ 0x0000000019af1f40 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:731: 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) @ 0x0000000019aeec7b 23. ./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) @ 0x000000001a934995 24. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 25. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 26. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 27. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 28. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 2025.06.12 18:58:14.662127 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:15.663369 [ 2897 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:16.397342 [ 3849 ] {ac7bb046-d223-46a7-8234-e35e0faa083d} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35552) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:16.398224 [ 3849 ] {ac7bb046-d223-46a7-8234-e35e0faa083d} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:16.664203 [ 2830 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:17.665034 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:18.028663 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c9916314-3fd0-4baf-9230-8fe33cf05dd8::all_1_6_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:18.667113 [ 2772 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:18.849958 [ 3849 ] {20ef2cc4-935a-4799-ada9-85d63cc5a3c6} 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.10057.altinitytest (altinity build)) (from [::1]:35560) (comment: 00177_memory_bound_merging.sh) (in query: SELECT COUNT() > 0 FROM system.text_log WHERE query_id IN (SELECT query_id FROM system.query_log WHERE query_id != 'query_id_memory_bound_merging_1435720713' AND initial_query_id = 'query_id_memory_bound_merging_1435720713' AND event_date >= yesterday()) AND event_date >= yesterday() AND message ILIKE '%Reading%ranges in order%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:18.851576 [ 3849 ] {20ef2cc4-935a-4799-ada9-85d63cc5a3c6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:19.145070 [ 3961 ] {592a849e-7472-40f9-8d7b-9368ac8e5b73} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Array(String)) of bloom filter index. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35626) (comment: 00908_bloom_filter_index.sh) (in query: CREATE TABLE bloom_filter_idx_na (`na` Array(Array(String)), INDEX bf na TYPE bloom_filter(0.1) GRANULARITY 1) ENGINE = MergeTree ORDER BY na SETTINGS index_granularity = 9801, min_bytes_for_wide_part = 412077644, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 25, min_bytes_for_full_part_storage = 263499292, compact_parts_max_bytes_to_buffer = 302187880, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 11354681, merge_max_block_size = 21981, old_parts_lifetime = 471., 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 = 8267226461, index_granularity_bytes = 15559193, concurrent_part_removal_threshold = 91, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 61904, primary_key_compress_block_size = 46080), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/BloomFilter.cpp:0: DB::BloomFilter::getPrimitiveType(std::shared_ptr const&) @ 0x0000000017c1ae43 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:925: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000019b50758 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019b2276b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000019b1ca0a 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000199a5830 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:722: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001999cbda 10. ./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) @ 0x000000001999b5e8 11. ./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>) @ 0x0000000019e411ad 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 15. ./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 @ 0x00000000191ba866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:19.147057 [ 3961 ] {592a849e-7472-40f9-8d7b-9368ac8e5b73} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Array(String)) of bloom filter index. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/BloomFilter.cpp:0: DB::BloomFilter::getPrimitiveType(std::shared_ptr const&) @ 0x0000000017c1ae43 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:925: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000019b50758 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019b2276b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:108: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000019b1ca0a 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000199a5830 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:722: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001999cbda 10. ./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) @ 0x000000001999b5e8 11. ./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>) @ 0x0000000019e411ad 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 15. ./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 @ 0x00000000191ba866 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:19.262029 [ 3659 ] {} ExternalDictionariesLoader: Could not load external dictionary 'a409dfad-4565-4c3c-80ca-6ea65ce90dc2', next update is scheduled at 2025-06-12 18:58:24: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb161ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000101d8583 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000101d760a 9. ./src/Dictionaries/PolygonDictionaryUtils.h:0: DB::GridRoot::makeCell(float, float, float, float, std::vector>, unsigned long)::'lambda'()::operator()() @ 0x00000000101d888b 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101fb6c2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000101fa278 12. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000101fa17e 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101fb3ad 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:19.667918 [ 2741 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:19.728178 [ 3961 ] {4949851f-75ef-4e20-9d3a-8840feb8f845} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35654) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:19.728693 [ 3961 ] {4949851f-75ef-4e20-9d3a-8840feb8f845} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:20.668825 [ 2810 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:21.672399 [ 2694 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:22.673553 [ 3165 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:23.077451 [ 3961 ] {d4c175ff-668e-46fd-8001-901e90c0ab18} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40188) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:23.078049 [ 3961 ] {d4c175ff-668e-46fd-8001-901e90c0ab18} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:23.423830 [ 3961 ] {2dcd88a6-f91e-4125-8200-e0f962d54394} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40202) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:23.424461 [ 3961 ] {2dcd88a6-f91e-4125-8200-e0f962d54394} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:23.674931 [ 3151 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:23.767720 [ 3961 ] {7b0bcd13-19cb-4ec1-bb26-90958708e2cd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40204) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:23.768360 [ 3961 ] {7b0bcd13-19cb-4ec1-bb26-90958708e2cd} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:24.676356 [ 3106 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:25.542156 [ 3961 ] {7ab160d3-5e9e-4ab7-86a3-29783b40742f} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST(NULL, 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40248) (comment: 02797_range_nullable.sql) (in query: SELECT range(Null::Nullable(UInt64), 10::Nullable(UInt64), 2::Nullable(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000f965f8e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961e0c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:25.543183 [ 3961 ] {7ab160d3-5e9e-4ab7-86a3-29783b40742f} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST(NULL, 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000f965f8e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961e0c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:25.554729 [ 3961 ] {15b58536-725b-40bb-bdfd-322615aa3569} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40248) (comment: 02797_range_nullable.sql) (in query: SELECT range(0::Nullable(UInt64), Null::Nullable(UInt64), 2::Nullable(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000f965f8e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961e0c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:25.555427 [ 3961 ] {15b58536-725b-40bb-bdfd-322615aa3569} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000f965f8e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961e0c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:25.654147 [ 3961 ] {9fde8f0f-68ad-48f4-8d7f-89298914252b} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40248) (comment: 02797_range_nullable.sql) (in query: SELECT range(0::Nullable(UInt64), 10::Nullable(UInt64), Null::Nullable(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000f965f8e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961e0c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:25.654961 [ 3961 ] {9fde8f0f-68ad-48f4-8d7f-89298914252b} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)')). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000f965f8e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961e0c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:25.677630 [ 3084 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:25.939247 [ 3961 ] {1017599f-e83a-4a55-b59b-bc033e6f386d} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Const(Nullable(UInt8)) of argument of function range. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40248) (comment: 02797_range_nullable.sql) (in query: SELECT range(Null::Nullable(UInt8), materialize(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000f965f8e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961e0c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 15. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 16. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:25.939841 [ 3961 ] {1017599f-e83a-4a55-b59b-bc033e6f386d} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Const(Nullable(UInt8)) of argument of function range. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000f965f8e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961e0c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 15. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 16. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:26.071396 [ 3961 ] {b081df78-96a2-41b8-976f-220974650564} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40268) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:26.075929 [ 3961 ] {b081df78-96a2-41b8-976f-220974650564} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:26.472928 [ 3961 ] {072a9cfb-1348-4ca1-8d26-129c62fd785a} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40270) (comment: 01670_dictionary_create_key_expression.sql) (in query: DROP DICTIONARY IF EXISTS database_dictionary_test_key_expression.test_query_log_dictionary_simple;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:26.475450 [ 3961 ] {072a9cfb-1348-4ca1-8d26-129c62fd785a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:26.679014 [ 3046 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:27.019280 [ 3961 ] {13a9197f-761f-496b-812e-70549e27fb01} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "x". (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40280) (comment: 02455_duplicate_column_names_in_schema_inference.sql) (in query: desc format(JSONEachRow, '{"x" : 1, "x" : 2}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28e832 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28fc14 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015eb3891 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018286adc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828587e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.019994 [ 3961 ] {13a9197f-761f-496b-812e-70549e27fb01} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "x". (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28e832 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28fc14 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015eb3891 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018286adc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828587e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.025415 [ 3961 ] {b1e06435-71d2-4797-a792-62004d6b3d91} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "x". (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40280) (comment: 02455_duplicate_column_names_in_schema_inference.sql) (in query: desc format(JSONEachRow, '{"x" : 1, "y" : 2}\n{"x" : 2, "x" : 3}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28e832 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28fc14 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015eb3891 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018286adc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828587e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.026008 [ 3961 ] {b1e06435-71d2-4797-a792-62004d6b3d91} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "x". (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28e832 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28fc14 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015eb3891 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018286adc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828587e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.032420 [ 3961 ] {686312c3-94b6-4c79-bdae-5e935effaaff} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSVWithNames format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "a". (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40280) (comment: 02455_duplicate_column_names_in_schema_inference.sql) (in query: desc format(CSVWithNames, 'a,b,a\n1,2,3');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28e832 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28fc14 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015eb3891 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018286adc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828587e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.033257 [ 3961 ] {686312c3-94b6-4c79-bdae-5e935effaaff} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSVWithNames format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "a". (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28e832 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28fc14 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015eb3891 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018286adc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828587e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.040572 [ 3961 ] {bc7ecdd4-aec8-473f-9431-4fded055d851} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "a". (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40280) (comment: 02455_duplicate_column_names_in_schema_inference.sql) (in query: desc format(CSV, '1,2,3') settings column_names_for_schema_inference='a, b, a';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28e832 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28fc14 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015eb3891 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018286adc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828587e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.041361 [ 3961 ] {bc7ecdd4-aec8-473f-9431-4fded055d851} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "a". (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28e832 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a28fc14 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015eb3891 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018286adc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828587e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.682560 [ 3024 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:27.775394 [ 3849 ] {e47cadb9-3bfb-4606-8b47-323cd55d3f1a} 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.10057.altinitytest (altinity build)) (from [::1]:40308) (comment: 02559_multiple_read_steps_in_prewhere_fuzz.sql) (in query: INSERT INTO test_02559__fuzz_20 SELECT number, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.777616 [ 3849 ] {e47cadb9-3bfb-4606-8b47-323cd55d3f1a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:27.829669 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3655178d-96ea-42c6-867f-61b9ceac796e::202506_1_26_5}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:28.702949 [ 2983 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:29.428627 [ 4203 ] {833c5606-d06a-45a0-a4e7-175d239f4257} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40342) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:29.429517 [ 4203 ] {833c5606-d06a-45a0-a4e7-175d239f4257} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:29.464879 [ 3849 ] {f97b97d6-2ea4-43c7-bf7f-e888be8231a3} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP sign (s) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40328) (comment: 01716_drop_rename_sign_column.sql) (in query: ALTER TABLE signed_table DROP COLUMN 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000019a74fa6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000199e576a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc8f9 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:29.465709 [ 3849 ] {f97b97d6-2ea4-43c7-bf7f-e888be8231a3} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP sign (s) column. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000019a74fa6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000199e576a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc8f9 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:29.695864 [ 3849 ] {d2d920f8-df77-406b-8bcd-7ec90111caa9} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME sign (s) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40328) (comment: 01716_drop_rename_sign_column.sql) (in query: ALTER TABLE signed_table RENAME COLUMN s TO s1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000019a74fa6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000199e561c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc8f9 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:29.696927 [ 3849 ] {d2d920f8-df77-406b-8bcd-7ec90111caa9} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME sign (s) column. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000019a74fa6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000199e561c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc8f9 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:29.711731 [ 2958 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:30.712815 [ 2936 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:31.350929 [ 3849 ] {4f169cbe-3269-4963-b722-1c5a0b295900} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 0, should be 1: In scope SELECT punycodeEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeEncode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:31.351625 [ 3849 ] {4f169cbe-3269-4963-b722-1c5a0b295900} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 0, should be 1: In scope SELECT punycodeEncode(). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:31.372673 [ 3849 ] {df5e4047-03e9-47df-89f8-10d832af4f4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 0, should be 1: In scope SELECT punycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:31.402412 [ 3849 ] {df5e4047-03e9-47df-89f8-10d832af4f4f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 0, should be 1: In scope SELECT punycodeDecode(). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:31.415075 [ 3849 ] {b884e3da-23ba-485c-a79e-78c2db7ca557} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 0, should be 1: In scope SELECT tryPunycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT tryPunycodeDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:31.415771 [ 3849 ] {b884e3da-23ba-485c-a79e-78c2db7ca557} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 0, should be 1: In scope SELECT tryPunycodeDecode(). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:31.677022 [ 3849 ] {61046d3e-a548-4590-9ae9-3ff161ffd06f} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function punycodeEncode: In scope SELECT punycodeEncode(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeEncode(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e0167ce 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:31.681032 [ 3849 ] {61046d3e-a548-4590-9ae9-3ff161ffd06f} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function punycodeEncode: In scope SELECT punycodeEncode(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e0167ce 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:31.727641 [ 5779 ] {0e5ffa89-856c-4a0f-8bb8-7679306631a3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column number): (while reading from part /var/lib/clickhouse/store/c99/c9916314-3fd0-4baf-9230-8fe33cf05dd8/all_1_1_0/ in table test_3.test (c9916314-3fd0-4baf-9230-8fe33cf05dd8) located on disk default of type local, from mark 7 with max_rows_to_read = 76380): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35224) (comment: 03002_filter_skip_virtual_columns_with_non_deterministic_functions.sql) (in query: select count() > 0 from test where RAND() > 4292390314;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5db1a 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5e04e 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fdcc4b 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 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>>&) @ 0x0000000019be070e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 2025.06.12 18:58:31.730811 [ 2921 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:31.789036 [ 5779 ] {0e5ffa89-856c-4a0f-8bb8-7679306631a3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column number): (while reading from part /var/lib/clickhouse/store/c99/c9916314-3fd0-4baf-9230-8fe33cf05dd8/all_1_1_0/ in table test_3.test (c9916314-3fd0-4baf-9230-8fe33cf05dd8) located on disk default of type local, from mark 7 with max_rows_to_read = 76380): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5db1a 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5e04e 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fdcc4b 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 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>>&) @ 0x0000000019be070e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 2025.06.12 18:58:31.952790 [ 3849 ] {089b44e9-f6b4-4c9b-b5c9-d9f07bfde573} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function punycodeDecode: In scope SELECT punycodeDecode(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeDecode(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionStringToString, DB::NamePunycodeDecode, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e0180ae 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:31.953518 [ 3849 ] {089b44e9-f6b4-4c9b-b5c9-d9f07bfde573} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function punycodeDecode: In scope SELECT punycodeDecode(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionStringToString, DB::NamePunycodeDecode, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e0180ae 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:32.005922 [ 3961 ] {4d348ddf-6e48-4e0f-a500-4597c98f6273} 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.10057.altinitytest (altinity build)) (from [::1]:53248) (comment: 02241_filesystem_cache_on_write_operations.sh) (in query: SELECT query, ProfileEvents['RemoteFSReadBytes'] > 0 as remote_fs_read FROM system.query_log WHERE query LIKE '%SELECT number, toString(number) FROM numbers(5000000)%' AND type = 'QueryFinish' AND current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.010144 [ 3961 ] {4d348ddf-6e48-4e0f-a500-4597c98f6273} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.294505 [ 3849 ] {9453afc4-f99c-49e9-a8ca-cd067e9893b5} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function tryPunycodeDecode: In scope SELECT tryPunycodeDecode(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT tryPunycodeDecode(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionStringToString, DB::NameTryPunycodeDecode, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e01970e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:32.296547 [ 3849 ] {9453afc4-f99c-49e9-a8ca-cd067e9893b5} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function tryPunycodeDecode: In scope SELECT tryPunycodeDecode(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionStringToString, DB::NameTryPunycodeDecode, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e01970e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:32.383909 [ 3849 ] {05bf8279-21ce-40ae-b1e4-585ccae92f74} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeEncode('two', 'strings');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.384964 [ 3849 ] {05bf8279-21ce-40ae-b1e4-585ccae92f74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode('two', 'strings'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.393439 [ 3849 ] {7a9c66cb-0004-4959-a714-371769c75d23} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeDecode('two', 'strings');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.393926 [ 3849 ] {7a9c66cb-0004-4959-a714-371769c75d23} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode('two', 'strings'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.404066 [ 3849 ] {aeb63c20-111d-4941-afde-503979b6330c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT tryPunycodeDecode('two', 'strings');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.404978 [ 3849 ] {aeb63c20-111d-4941-afde-503979b6330c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode('two', 'strings'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871762c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008714669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.724758 [ 3849 ] {049c9b57-63b0-4e79-b7aa-e6179a57c90d} executeQuery: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT punycodeEncode(toFixedString('two', 3)). (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeEncode(toFixedString('two', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::PunycodeEncode::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e01724f 5. DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e016499 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:32.731810 [ 2898 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:32.739032 [ 3849 ] {049c9b57-63b0-4e79-b7aa-e6179a57c90d} TCPHandler: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT punycodeEncode(toFixedString('two', 3)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::PunycodeEncode::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e01724f 5. DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e016499 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:32.854741 [ 4203 ] {fb81405b-507e-457d-8292-280a9a78d695} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53280) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:32.855406 [ 4203 ] {fb81405b-507e-457d-8292-280a9a78d695} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:33.737796 [ 2883 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:34.217591 [ 3849 ] {c0ae0005-dfd5-49a7-b43c-0032ffcc59c0} executeQuery: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT punycodeDecode(toFixedString('two', 3)). (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeDecode(toFixedString('two', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::PunycodeDecode<(DB::ErrorHandling)0>::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e018a8f 5. DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e017d79 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:34.238429 [ 3849 ] {c0ae0005-dfd5-49a7-b43c-0032ffcc59c0} TCPHandler: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT punycodeDecode(toFixedString('two', 3)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::PunycodeDecode<(DB::ErrorHandling)0>::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e018a8f 5. DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e017d79 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:34.742907 [ 2981 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:35.089785 [ 3849 ] {a6ee10d0-328b-480d-b15f-52f140689bf3} executeQuery: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT tryPunycodeDecode(toFixedString('two', 3)). (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT tryPunycodeDecode(toFixedString('two', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::PunycodeDecode<(DB::ErrorHandling)1>::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e01a08f 5. DB::FunctionStringToString, DB::NameTryPunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0193d9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:35.091579 [ 3849 ] {a6ee10d0-328b-480d-b15f-52f140689bf3} TCPHandler: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT tryPunycodeDecode(toFixedString('two', 3)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::PunycodeDecode<(DB::ErrorHandling)1>::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e01a08f 5. DB::FunctionStringToString, DB::NameTryPunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0193d9 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:35.449946 [ 4203 ] {98508fdd-3fc4-4150-99b0-fb8190ef53f3} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53290) (comment: 01685_ssd_cache_dictionary_complex_key.sh) (in query: DROP DICTIONARY cache_dictionary_complex_key_simple_attributes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:35.460459 [ 4203 ] {98508fdd-3fc4-4150-99b0-fb8190ef53f3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:35.752978 [ 2856 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:36.211492 [ 4203 ] {d53ddf23-0993-4f2b-82b0-06438b34bb3f} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53304) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:36.212976 [ 4203 ] {d53ddf23-0993-4f2b-82b0-06438b34bb3f} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:36.755034 [ 2834 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:37.354947 [ 3849 ] {998768fb-5b66-4dbf-ad31-cf84de8fcb5d} executeQuery: Code: 36. DB::Exception: 'no punycode' is not a valid Punycode-encoded string: In scope SELECT punycodeDecode('no punycode'). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT punycodeDecode('no punycode');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x0000000007b45440 4. DB::PunycodeDecode<(DB::ErrorHandling)0>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e018979 5. DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e017b54 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:37.356817 [ 3849 ] {998768fb-5b66-4dbf-ad31-cf84de8fcb5d} TCPHandler: Code: 36. DB::Exception: 'no punycode' is not a valid Punycode-encoded string: In scope SELECT punycodeDecode('no punycode'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x0000000007b45440 4. DB::PunycodeDecode<(DB::ErrorHandling)0>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e018979 5. DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e017b54 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 18:58:37.754830 [ 3961 ] {9150ca9e-c271-412c-8219-64897cde5b9d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53328) (comment: 01517_drop_mv_with_inner_table.sql) (in query: -- drops it and hangs with Atomic engine, due to recursive DROP drop table db_01517_atomic_sync.mv 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 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) @ 0x0000000017c70371 10. ./build_docker/./src/Storages/StorageMaterializedView.cpp:355: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000192ae986 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:37.757453 [ 3961 ] {9150ca9e-c271-412c-8219-64897cde5b9d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 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) @ 0x0000000017c70371 10. ./build_docker/./src/Storages/StorageMaterializedView.cpp:355: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000192ae986 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:37.770876 [ 2806 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:38.090882 [ 3849 ] {f246faf8-ef02-48b2-b09f-d9f1d83a32d9} executeQuery: Code: 36. DB::Exception: 'Also no punycode' is not a valid Punycode-encoded string: while executing 'FUNCTION punycodeDecode(__table1.puny : 1) -> punycodeDecode(__table1.puny) String : 0'. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40352) (comment: 02932_punycode.sql) (in query: SELECT puny, punycodeDecode(puny) AS original 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x0000000007b45440 4. DB::PunycodeDecode<(DB::ErrorHandling)0>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e018979 5. DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e017b54 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:38.092782 [ 3849 ] {f246faf8-ef02-48b2-b09f-d9f1d83a32d9} TCPHandler: Code: 36. DB::Exception: 'Also no punycode' is not a valid Punycode-encoded string: while executing 'FUNCTION punycodeDecode(__table1.puny : 1) -> punycodeDecode(__table1.puny) String : 0'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x0000000007b45440 4. DB::PunycodeDecode<(DB::ErrorHandling)0>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e018979 5. DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e017b54 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:38.622137 [ 3849 ] {df0081c2-afd4-43b8-84d2-a3a62e3fa119} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53332) (comment: 01070_exception_code_in_query_log_table.sql) (in query: SELECT * FROM test_table_for_01070_exception_code_in_query_log_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:38.625053 [ 3849 ] {df0081c2-afd4-43b8-84d2-a3a62e3fa119} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:38.784349 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:39.204409 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {14a4948f-ad6d-4f55-847a-9babfee874f5::202506_1_66_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:39.659169 [ 3748 ] {830f8781-7732-4406-b80d-de20d3f03e7f} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53378) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:39.659962 [ 3748 ] {830f8781-7732-4406-b80d-de20d3f03e7f} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:39.792072 [ 3107 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:40.358390 [ 4203 ] {5ada9e2e-d23d-4568-9908-c7bb507f3f0d} executeQuery: Code: 164. DB::Exception: Cannot modify 'output_format_json_quote_64bit_integers' setting in readonly mode. (READONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53388) (comment: 00474_readonly_settings.sh) (in query: set output_format_json_quote_64bit_integers=0 ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000015e5ccbe 3. ./build_docker/./src/Access/SettingsConstraints.cpp:307: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016825fa4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:40.360181 [ 4203 ] {5ada9e2e-d23d-4568-9908-c7bb507f3f0d} TCPHandler: Code: 164. DB::Exception: Cannot modify 'output_format_json_quote_64bit_integers' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000015e5ccbe 3. ./build_docker/./src/Access/SettingsConstraints.cpp:307: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016825fa4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:40.721976 [ 3961 ] {} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=793, jobs=769). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017f15902 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x0000000017f11b3f 9. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x0000000017f0e817 10. ./build_docker/./src/Server/HTTPHandler.cpp:220: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a12b24f 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:40.795075 [ 2741 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:41.797873 [ 2730 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:42.606360 [ 3961 ] {b3855c37-aa90-4f17-8c6c-a6ad75df2f7d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42962) (comment: 00873_t64_codec_date.sql) (in query: SELECT * FROM t64 ORDER BY date_32;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:42.617014 [ 3961 ] {b3855c37-aa90-4f17-8c6c-a6ad75df2f7d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:42.801009 [ 2697 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:43.153999 [ 3961 ] {1de0a63a-52d2-450e-a211-c5c0cd661edb} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.src does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42980) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: DROP TABLE src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696fa4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a83b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:43.155357 [ 3961 ] {1de0a63a-52d2-450e-a211-c5c0cd661edb} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.src 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696fa4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a83b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:43.296313 [ 3748 ] {27a2f8c2-e6d9-42e5-9257-139254a9e779} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): while reading column id at /var/lib/clickhouse/store/7c3/7c396ae0-cae4-4121-ae13-5ab05b3ab607/: While executing Log: While executing SourceFromQueryPipeline: while executing 'FUNCTION dictHas('simple_key_dictionary'_String : 1, __table1.number : 5) -> dictHas('simple_key_dictionary'_String, __table1.number) UInt8 : 0'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42970) (comment: 01780_dict_get_or_null.sql) (in query: SELECT number, dictHas('simple_key_dictionary', number), dictGetOrNull('simple_key_dictionary', 'value', number), dictGetOrNull('simple_key_dictionary', 'value_nullable', number), dictGetOrNull('simple_key_dictionary', ('value', 'value_nullable'), number) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000000fcb2bd7 14. DB::ReadBuffer::next() @ 0x0000000007b3417b 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5ae03 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000016d5a871 17. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000016d5ab2e 18. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fdcc4b 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x00000000195b5397 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000195b42b4 22. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 28. DB::SourceFromQueryPipeline::generate() @ 0x000000001027742b 29. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 18:58:43.301046 [ 3748 ] {27a2f8c2-e6d9-42e5-9257-139254a9e779} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): while reading column id at /var/lib/clickhouse/store/7c3/7c396ae0-cae4-4121-ae13-5ab05b3ab607/: While executing Log: While executing SourceFromQueryPipeline: while executing 'FUNCTION dictHas('simple_key_dictionary'_String : 1, __table1.number : 5) -> dictHas('simple_key_dictionary'_String, __table1.number) UInt8 : 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000000fcb2bd7 14. DB::ReadBuffer::next() @ 0x0000000007b3417b 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5ae03 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000016d5a871 17. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000016d5ab2e 18. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fdcc4b 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x00000000195b5397 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000195b42b4 22. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 28. DB::SourceFromQueryPipeline::generate() @ 0x000000001027742b 29. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 18:58:43.806885 [ 3169 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:44.140178 [ 3748 ] {829fd5f5-ae1a-48b4-b9ac-d31fdbe971af} executeQuery: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): arrayJoin([0, 1]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42994) (comment: 02009_array_join_partition.sql) (in query: ALTER TABLE table_2009_part ATTACH PARTITION tuple(arrayJoin([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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000181e1876 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181e1df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e3f08 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000019a02bd0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20cbf 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:44.143573 [ 3748 ] {829fd5f5-ae1a-48b4-b9ac-d31fdbe971af} TCPHandler: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): arrayJoin([0, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000181e1876 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181e1df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e3f08 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000019a02bd0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20cbf 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:44.283370 [ 3748 ] {a3cf5dde-a3ad-473b-bda0-69df3ebeb96c} executeQuery: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): toYYYYMM(toDate(array(arrayJoin(array(arrayJoin(array(arrayJoin(array(arrayJoin(array(3, materialize(NULL), arrayJoin(array(1025, materialize(NULL), materialize(NULL))), NULL)))))), materialize(NULL)))), NULL)). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42994) (comment: 02009_array_join_partition.sql) (in query: ALTER TABLE table_2009_part ATTACH PARTITION tuple(toYYYYMM(toDate([arrayJoin([arrayJoin([arrayJoin([arrayJoin([3, materialize(NULL), arrayJoin([1025, materialize(NULL), materialize(NULL)]), NULL])])]), materialize(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000181e1876 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181e1df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e3f08 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000019a02bd0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20cbf 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:44.288524 [ 3748 ] {a3cf5dde-a3ad-473b-bda0-69df3ebeb96c} TCPHandler: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): toYYYYMM(toDate(array(arrayJoin(array(arrayJoin(array(arrayJoin(array(arrayJoin(array(3, materialize(NULL), arrayJoin(array(1025, materialize(NULL), materialize(NULL))), NULL)))))), materialize(NULL)))), NULL)). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000181e1876 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181e1df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e3f08 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000019a02bd0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20cbf 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:44.810194 [ 3130 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:45.144760 [ 3961 ] {fb7d76fb-65ef-4e4d-80a2-b675e151b944} executeQuery: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43030) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x0000000019b8e9cf 5. ./src/Storages/MergeTree/MergeTreeIndices.h:174: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x0000000019b2884a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:310: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x0000000019ac091e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019abf618 8. ./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&) @ 0x0000000019ab1b04 9. ./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&) @ 0x0000000019aa0f97 10. ./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&) @ 0x0000000019abcf92 11. ./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&) @ 0x0000000019c7ff6b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd02d8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 16. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 17. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 22. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 23. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 24. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:45.149825 [ 3961 ] {fb7d76fb-65ef-4e4d-80a2-b675e151b944} TCPHandler: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x0000000019b8e9cf 5. ./src/Storages/MergeTree/MergeTreeIndices.h:174: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x0000000019b2884a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:310: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x0000000019ac091e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019abf618 8. ./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&) @ 0x0000000019ab1b04 9. ./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&) @ 0x0000000019aa0f97 10. ./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&) @ 0x0000000019abcf92 11. ./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&) @ 0x0000000019c7ff6b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd02d8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 16. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 17. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 22. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 23. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 24. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:45.191504 [ 3748 ] {5f4b4a90-9308-4329-a673-423817c0d644} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43042) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:45.192015 [ 3748 ] {5f4b4a90-9308-4329-a673-423817c0d644} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:45.482226 [ 3961 ] {6c1de5b9-a325-46bb-bd0c-4414b70b185a} executeQuery: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43030) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x0000000019b8e9cf 5. ./src/Storages/MergeTree/MergeTreeIndices.h:174: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x0000000019b2884a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:310: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x0000000019ac091e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019abf618 8. ./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&) @ 0x0000000019ab1b04 9. ./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&) @ 0x0000000019aa0f97 10. ./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&) @ 0x0000000019abcf92 11. ./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&) @ 0x0000000019c7ff6b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd02d8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 16. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 17. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 22. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 23. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 24. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:45.485875 [ 3961 ] {6c1de5b9-a325-46bb-bd0c-4414b70b185a} TCPHandler: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x0000000019b8e9cf 5. ./src/Storages/MergeTree/MergeTreeIndices.h:174: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x0000000019b2884a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:310: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x0000000019ac091e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000019abf618 8. ./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&) @ 0x0000000019ab1b04 9. ./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&) @ 0x0000000019aa0f97 10. ./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&) @ 0x0000000019abcf92 11. ./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&) @ 0x0000000019c7ff6b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd02d8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 16. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 17. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 22. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 23. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 24. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:58:45.598153 [ 3748 ] {4b07d620-6655-4140-92ef-33a350d8dd88} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43056) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r2 ATTACH PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:45.600512 [ 3748 ] {4b07d620-6655-4140-92ef-33a350d8dd88} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:45.821217 [ 3088 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:46.741231 [ 3966 ] {e692df8c-fbc1-49ca-9495-6ec69bb6def3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42988) (comment: 01055_compact_parts.sql) (in query: select * from mt_compact order by a, s limit 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 2025.06.12 18:58:46.754242 [ 3966 ] {e692df8c-fbc1-49ca-9495-6ec69bb6def3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 2025.06.12 18:58:46.827823 [ 3069 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:47.833836 [ 3197 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:48.838903 [ 3008 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:48.940802 [ 3966 ] {30668b7e-bcdc-4691-b3ef-9e7afae4b00a} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43088) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r2 ATTACH PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:48.942012 [ 3966 ] {30668b7e-bcdc-4691-b3ef-9e7afae4b00a} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:49.844944 [ 3025 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:50.847303 [ 2958 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:51.855197 [ 2930 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:52.337265 [ 3966 ] {17edfe2a-418e-4ee9-ad37-951c85124fb7} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36946) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r2 ATTACH PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:52.340246 [ 3966 ] {17edfe2a-418e-4ee9-ad37-951c85124fb7} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:52.860724 [ 2922 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:53.870670 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:54.873085 [ 2869 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:55.734695 [ 3528 ] {446f9950-e105-4a52-8e3a-0eef6f9a5182} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37004) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r2 ATTACH PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:55.736698 [ 3528 ] {446f9950-e105-4a52-8e3a-0eef6f9a5182} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:55.880663 [ 2844 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:56.886808 [ 2808 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:57.892781 [ 2789 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:57.926243 [ 3966 ] {c24d9999-eb12-4b2e-9b0d-24f6884f4801} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=771). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36988) (comment: 01353_nullable_tuple.sql) (in query: select tuple(toNullable(number), toNullable(number)) < tuple(number, number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:57.928369 [ 3966 ] {c24d9999-eb12-4b2e-9b0d-24f6884f4801} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=771). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:58.898395 [ 2764 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:58:59.112468 [ 3528 ] {2bff0221-007c-4939-8898-2278d0e52d82} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37022) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r2 ATTACH PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:59.113515 [ 3528 ] {2bff0221-007c-4939-8898-2278d0e52d82} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:58:59.902760 [ 2749 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:00.903935 [ 2736 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:01.789574 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_66_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:01.914374 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:02.197669 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_1_48_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:02.459094 [ 3528 ] {b1fc0926-f497-470c-a6d2-320fff495e91} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38950) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:02.459622 [ 3528 ] {b1fc0926-f497-470c-a6d2-320fff495e91} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:02.883203 [ 3528 ] {3c3c8be4-2135-4fe6-b3ac-66f4d95e9243} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38962) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:02.884253 [ 3528 ] {3c3c8be4-2135-4fe6-b3ac-66f4d95e9243} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:02.917462 [ 3166 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:03.218622 [ 3528 ] {bb03ddc7-f419-4851-890e-1a9b4ef7ed3e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38964) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:03.219600 [ 3528 ] {bb03ddc7-f419-4851-890e-1a9b4ef7ed3e} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:03.390151 [ 3966 ] {c6430c6c-d4b9-44f8-9fbd-0412fa48843a} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37056) (comment: 02425_categorical_information_value_properties.sql) (in query: SELECT categoricalInformationValue(c1, c2) FROM VALUES((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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000015afdb21 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x0000000016229574 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:03.392804 [ 3966 ] {c6430c6c-d4b9-44f8-9fbd-0412fa48843a} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000015afdb21 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x0000000016229574 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:03.708591 [ 3966 ] {dc785a35-82c9-4cf9-963d-a9b405089c27} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37056) (comment: 02425_categorical_information_value_properties.sql) (in query: SELECT categoricalInformationValue(c1, c2) FROM VALUES((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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000015afdb21 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x0000000016229574 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:03.709381 [ 3966 ] {dc785a35-82c9-4cf9-963d-a9b405089c27} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000015afdb21 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x0000000016229574 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:03.938923 [ 3140 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:04.945244 [ 3116 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:05.957593 [ 3082 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:06.066459 [ 3528 ] {30677609-63d8-4c9d-a20f-214392386472} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39048) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO dst_r1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:06.068325 [ 3528 ] {30677609-63d8-4c9d-a20f-214392386472} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:06.780478 [ 3966 ] {cc693cca-bad0-4312-a5d4-a4900c831f43} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39076) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:06.781282 [ 3966 ] {cc693cca-bad0-4312-a5d4-a4900c831f43} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:06.964442 [ 3058 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:07.968412 [ 3027 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:08.972458 [ 2995 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:09.978855 [ 2999 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:10.114678 [ 3528 ] {6b642ae2-6b77-41a9-9870-a554ee2fbdca} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39110) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:10.115309 [ 3528 ] {6b642ae2-6b77-41a9-9870-a554ee2fbdca} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:10.984598 [ 2952 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:11.495094 [ 3528 ] {bff1ff2e-0b08-4a04-8bbb-b5b0e6b4ac54} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=771). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39112) (comment: 02286_parallel_final.sh) (in query: insert into tbl_8parts_8granules_rnd select number, 1 from numbers_mt(524288);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2dfc33 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1d90cc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:11.498169 [ 3528 ] {bff1ff2e-0b08-4a04-8bbb-b5b0e6b4ac54} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=771). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2dfc33 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1d90cc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:11.989232 [ 2985 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:13.080420 [ 3966 ] {d2617146-7d0c-4153-b15e-2a8c9d91b762} 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.10057.altinitytest (altinity build)) (from [::1]:36202) (comment: 00933_test_fix_extra_seek_on_compressed_cache.sh) (in query: SELECT ProfileEvents['Seek'], ProfileEvents['ReadCompressedBytes'], ProfileEvents['UncompressedCacheHits'] AS hit FROM system.query_log WHERE query_id = 'test-query-uncompressed-cache' AND current_database = currentDatabase() 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:13.095418 [ 3966 ] {d2617146-7d0c-4153-b15e-2a8c9d91b762} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:13.108836 [ 2904 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:13.565689 [ 3966 ] {34cb5658-e20c-4c6f-9abb-523807e5088d} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36228) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:13.566277 [ 3966 ] {34cb5658-e20c-4c6f-9abb-523807e5088d} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:14.116391 [ 3152 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:15.140526 [ 2859 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:15.530603 [ 4101 ] {285a5b2d-2fab-4574-aef9-cb73c8484ed0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39802) (comment: 02518_qualified_asterisks_alias_table_name.sql) (in query: DROP DATABASE IF EXISTS test_wmc1nbhx ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:15.549467 [ 4101 ] {285a5b2d-2fab-4574-aef9-cb73c8484ed0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:16.143146 [ 2836 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:16.911783 [ 3528 ] {0daa7708-b912-4345-a273-3763fd099ea1} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36272) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:16.912477 [ 3528 ] {0daa7708-b912-4345-a273-3763fd099ea1} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:16.998731 [ 3826 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:16.998630 [ 3966 ] {3cee33ef-8e21-48e1-8342-843c97b1baca} executeQuery: Code: 131. DB::Exception: Too long name of aggregate function, maximum: 1000. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36250) (comment: 02688_long_aggregate_function_names.sql) (in query: SELECT minOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNull(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000008671800 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:323: DB::AggregateFunctionFactory::isAggregateFunctionName(String const&) const @ 0x000000001622c6e9 5. ./src/Analyzer/Resolve/ExpressionsStack.h:23: DB::ExpressionsStack::push(std::shared_ptr const&) @ 0x0000000017506601 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolveScope.cpp:107: DB::IdentifierResolveScope::pushExpressionNode(std::shared_ptr const&) @ 0x0000000017504485 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174998b1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:17.001859 [ 3966 ] {3cee33ef-8e21-48e1-8342-843c97b1baca} TCPHandler: Code: 131. DB::Exception: Too long name of aggregate function, maximum: 1000. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000008671800 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:323: DB::AggregateFunctionFactory::isAggregateFunctionName(String const&) const @ 0x000000001622c6e9 5. ./src/Analyzer/Resolve/ExpressionsStack.h:23: DB::ExpressionsStack::push(std::shared_ptr const&) @ 0x0000000017506601 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolveScope.cpp:107: DB::IdentifierResolveScope::pushExpressionNode(std::shared_ptr const&) @ 0x0000000017504485 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174998b1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:17.152147 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:17.759950 [ 3826 ] {83eb3d5b-8dca-42ab-ab97-624918cc628c} 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.10057.altinitytest (altinity build)) (from [::1]:36308) (comment: 00285_not_all_data_in_totals.sql) (in query: SELECT ignore(x), count() FROM (SELECT number AS x FROM system.numbers LIMIT 1000 UNION ALL SELECT number AS x FROM system.numbers LIMIT 1000) GROUP BY x WITH TOTALS LIMIT 10 FORMAT JSONCompact;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:17.772829 [ 3826 ] {83eb3d5b-8dca-42ab-ab97-624918cc628c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:17.831405 [ 3528 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:18.154804 [ 2788 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:18.174280 [ 3826 ] {dcb62fcc-76dc-41e6-b382-46e8a0efcc1a} executeQuery: Code: 60. DB::Exception: Table test_9.ghdata_2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36322) (comment: 01825_type_json_ghdata_insert_select.sh) (in query: INSERT INTO ghdata_2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:18.175279 [ 3826 ] {dcb62fcc-76dc-41e6-b382-46e8a0efcc1a} TCPHandler: Code: 60. DB::Exception: Table test_9.ghdata_2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:18.851038 [ 3528 ] {7248a904-4196-45ef-be57-b99ee4e0f7b6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32786) (comment: 00579_merge_tree_partition_and_primary_keys_using_same_expression.sql) (in query: DROP DATABASE IF EXISTS test_92w0gzea ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:18.861012 [ 3528 ] {7248a904-4196-45ef-be57-b99ee4e0f7b6} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:18.871255 [ 3826 ] {3f4295ff-d090-4982-975c-e9f6280ce516} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32790) (comment: 00579_merge_tree_partition_and_primary_keys_using_same_expression.sql) (in query: DROP DATABASE IF EXISTS test_92w0gzea ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:18.874731 [ 3826 ] {3f4295ff-d090-4982-975c-e9f6280ce516} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:18.885569 [ 3528 ] {3b41b6ec-5b6c-48cc-8991-1241d663e0b4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32792) (comment: 00579_merge_tree_partition_and_primary_keys_using_same_expression.sql) (in query: DROP DATABASE IF EXISTS test_92w0gzea ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:18.888168 [ 3528 ] {3b41b6ec-5b6c-48cc-8991-1241d663e0b4} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:19.007131 [ 3826 ] {e80fe6f9-d2fc-43d3-8cef-6a17b8e3abdc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32796) (comment: 00579_merge_tree_partition_and_primary_keys_using_same_expression.sql) (in query: DROP DATABASE IF EXISTS test_92w0gzea ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:19.008025 [ 3826 ] {e80fe6f9-d2fc-43d3-8cef-6a17b8e3abdc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:19.156180 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:20.159570 [ 2732 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:20.274592 [ 3826 ] {32cd3a29-551f-415c-9abf-6b466e3cc770} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36368) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:20.275453 [ 3826 ] {32cd3a29-551f-415c-9abf-6b466e3cc770} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:21.167141 [ 2715 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:22.171792 [ 2683 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:23.176763 [ 3161 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:24.181621 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:24.379963 [ 4083 ] {645075c9-e12a-4e1a-8c88-fb0132513c09} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57744) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:24.386911 [ 4083 ] {645075c9-e12a-4e1a-8c88-fb0132513c09} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:24.759341 [ 5737 ] {9e9dcd63-8552-4345-8054-e4bcf5826e47} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57754) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:24.759983 [ 5737 ] {9e9dcd63-8552-4345-8054-e4bcf5826e47} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:25.128570 [ 4083 ] {4bd8ce5c-5290-4821-bb20-3f79c1152115} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57768) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:25.129258 [ 4083 ] {4bd8ce5c-5290-4821-bb20-3f79c1152115} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:25.187876 [ 3114 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:25.211034 [ 5737 ] {be91ca85-0425-49c9-bfdc-210142526a18} executeQuery: Code: 60. DB::Exception: Table test_9.ghdata_2_from_string does not exist. Maybe you meant test_9.ghdata_2_string?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57762) (comment: 01825_type_json_ghdata_insert_select.sh) (in query: INSERT INTO ghdata_2_from_string SELECT data FROM ghdata_2_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:25.213857 [ 5737 ] {be91ca85-0425-49c9-bfdc-210142526a18} TCPHandler: Code: 60. DB::Exception: Table test_9.ghdata_2_from_string does not exist. Maybe you meant test_9.ghdata_2_string?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:25.849125 [ 3528 ] {996d7839-450c-45cf-9046-ad725c203c5f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata_2_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string). (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57784) (comment: 01825_type_json_ghdata_insert_select.sh) (in query: SELECT (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string) = (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499a1d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5108 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:25.854222 [ 3528 ] {996d7839-450c-45cf-9046-ad725c203c5f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata_2_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499a1d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5108 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:26.193662 [ 3085 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:26.279734 [ 3826 ] {0ddae754-780c-4cfc-a77e-5b7c9655e136} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57812) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:26.281654 [ 3826 ] {0ddae754-780c-4cfc-a77e-5b7c9655e136} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:26.526197 [ 3528 ] {8c9066d1-1417-4430-bff2-c1491bded55c} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_3jzrlyq5.v (2fdd7c03-a856-4d4a-8ac1-434238bec47e), because some tables depend on it: test_3jzrlyq5.dict. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57804) (comment: 03243_create_or_replace_view_dependency_check.sql) (in query: drop view 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: 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>&&) @ 0x00000000176ab726 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000176a246d 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000176a2955 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bf47 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:26.529923 [ 3528 ] {8c9066d1-1417-4430-bff2-c1491bded55c} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_3jzrlyq5.v (2fdd7c03-a856-4d4a-8ac1-434238bec47e), because some tables depend on it: test_3jzrlyq5.dict. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: 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>&&) @ 0x00000000176ab726 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000176a246d 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000176a2955 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bf47 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:26.589242 [ 3528 ] {a7f8641c-c792-4c62-ada1-f6e2332cb716} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57804) (comment: 03243_create_or_replace_view_dependency_check.sql) (in query: drop view 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:26.590615 [ 3528 ] {a7f8641c-c792-4c62-ada1-f6e2332cb716} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:26.653803 [ 5737 ] {88dee525-4dfc-4b23-b5ad-0126a04b9c84} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35288) (comment: 03243_create_or_replace_view_dependency_check.sql) (in query: DROP DATABASE IF EXISTS test_3jzrlyq5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 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>>>&) @ 0x0000000017c6e9aa 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:26.655601 [ 5737 ] {88dee525-4dfc-4b23-b5ad-0126a04b9c84} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 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>>>&) @ 0x0000000017c6e9aa 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:27.196056 [ 3060 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:28.105548 [ 3528 ] {cba17e37-1846-4197-9cc7-d6de6fd62ce9} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57844) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.106534 [ 3528 ] {cba17e37-1846-4197-9cc7-d6de6fd62ce9} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.124067 [ 3528 ] {2cfa35dc-119d-4eda-aaef-056cabbd00d8} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57844) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.125871 [ 3528 ] {2cfa35dc-119d-4eda-aaef-056cabbd00d8} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.139553 [ 3528 ] {328ae1e9-d663-4961-be7e-70c3f7ed4126} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57844) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.141158 [ 3528 ] {328ae1e9-d663-4961-be7e-70c3f7ed4126} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.153683 [ 3528 ] {c5013cd8-619d-42aa-9c6e-4c7b79b92bf3} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57844) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.154313 [ 3528 ] {c5013cd8-619d-42aa-9c6e-4c7b79b92bf3} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.167595 [ 3528 ] {f0e52e55-32f1-494f-a3fd-4ebc0edc0975} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57844) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.169084 [ 3528 ] {f0e52e55-32f1-494f-a3fd-4ebc0edc0975} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.181756 [ 3528 ] {8aab3157-dbd4-4b45-b06d-04854e5571b6} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57844) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.182849 [ 3528 ] {8aab3157-dbd4-4b45-b06d-04854e5571b6} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.198143 [ 3042 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:28.213515 [ 3528 ] {d835b169-3f12-4eb0-8bdc-d4ebed9c2079} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((5., 5.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57844) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((5.0, 5.0), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.215448 [ 3528 ] {d835b169-3f12-4eb0-8bdc-d4ebed9c2079} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((5., 5.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.234081 [ 3528 ] {92a5bc96-5293-4259-8dc8-9ca702d8c411} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57844) (comment: 00500_point_in_polygon.sql) (in query: SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.235076 [ 3528 ] {92a5bc96-5293-4259-8dc8-9ca702d8c411} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d76c9e4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 18:59:28.526555 [ 5737 ] {8794cf95-449d-4db3-9020-6b6e484d53b0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57860) (comment: 01078_bloom_filter_operator_not_has.sql) (in query: SELECT count() FROM bloom_filter_not_has WHERE NOT has(ary, '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1a787 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:28.527800 [ 5737 ] {8794cf95-449d-4db3-9020-6b6e484d53b0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1a787 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:28.867217 [ 5779 ] {06388058-0a04-4060-b50b-cc613508140a} executeQuery: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57730) (comment: 02286_parallel_final.sh) (in query: optimize table tbl_8parts_5granules_seq final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 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) @ 0x0000000019e53e16 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) @ 0x0000000019e5ab6b 11. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:28.869765 [ 5779 ] {06388058-0a04-4060-b50b-cc613508140a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 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) @ 0x0000000019e53e16 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) @ 0x0000000019e5ab6b 11. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:29.217135 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:29.537176 [ 5737 ] {43b0b7be-0b3e-44c1-9cce-a7e0de58e1bb} executeQuery: Code: 57. DB::Exception: Table test_9.test_null_as_default already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57874) (comment: 01846_null_as_default_for_insert_select.sql) (in query: CREATE TABLE test_null_as_default (a Int8, b Int64 DEFAULT a + 1000) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:29.539935 [ 5737 ] {43b0b7be-0b3e-44c1-9cce-a7e0de58e1bb} TCPHandler: Code: 57. DB::Exception: Table test_9.test_null_as_default already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:29.743148 [ 3849 ] {317b205e-0ed9-4bc6-98d4-0be0883cacf2} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57894) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:29.743742 [ 3849 ] {317b205e-0ed9-4bc6-98d4-0be0883cacf2} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:29.992657 [ 3849 ] {e4a5bd96-cccf-41a1-a52a-8cd793c4046e} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57906) (comment: 01523_date_time_compare_with_date_literal.sql) (in query: CREATE TABLE test (`timestamp` DateTime) ENGINE = MergeTree ORDER BY timestamp SETTINGS index_granularity = 32212, min_bytes_for_wide_part = 1071109671, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 2, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 373954168, compact_parts_max_granules_to_buffer = 254, compact_parts_merge_max_bytes_to_prefetch_part = 33346144, merge_max_block_size = 20744, old_parts_lifetime = 273., prefer_fetch_merged_part_size_threshold = 1917435408, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 53, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16776197, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 30723, primary_key_compress_block_size = 54136), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:30.000385 [ 3849 ] {e4a5bd96-cccf-41a1-a52a-8cd793c4046e} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:30.221001 [ 2994 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:31.222668 [ 2955 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:31.824260 [ 3849 ] {3778fe67-13e9-4f68-8a29-7775f7b8680d} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57926) (comment: 02025_nested_func_for_if_combinator.sql) (in query: SELECT uniqCombinedIfMergeIf(n, last > 50) FILTER(WHERE last>50) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b7b6 5. ./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 @ 0x00000000162292ab 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:31.825277 [ 3849 ] {3778fe67-13e9-4f68-8a29-7775f7b8680d} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b7b6 5. ./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 @ 0x00000000162292ab 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:32.021185 [ 3849 ] {70947a33-3880-46e0-adec-81a3f64b4e6b} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57926) (comment: 02025_nested_func_for_if_combinator.sql) (in query: SELECT uniqCombinedIfMergeIfIf(n, last > 5) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b7b6 5. ./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 @ 0x00000000162292ab 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:32.021880 [ 3849 ] {70947a33-3880-46e0-adec-81a3f64b4e6b} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b7b6 5. ./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 @ 0x00000000162292ab 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:32.035922 [ 3849 ] {846771de-1c7e-4ebd-a601-a4ba781f355f} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57926) (comment: 02025_nested_func_for_if_combinator.sql) (in query: SELECT uniqCombinedIfMergeIfIf(n, last > 5, 1) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b7b6 5. ./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 @ 0x00000000162292ab 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:32.036848 [ 3849 ] {846771de-1c7e-4ebd-a601-a4ba781f355f} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b7b6 5. ./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 @ 0x00000000162292ab 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:32.223721 [ 2929 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:32.443276 [ 3849 ] {72a366ee-3eb8-494b-a3dc-0ec53ac1208b} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46834) (comment: 01861_explain_pipeline.sql) (in query: CREATE TABLE test (`a` Int, `b` Int) ENGINE = ReplacingMergeTree ORDER BY a SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 454568081, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 21949026, merge_max_block_size = 598, old_parts_lifetime = 379., prefer_fetch_merged_part_size_threshold = 1297017135, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 5246500477, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 24488, primary_key_compress_block_size = 17080), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:32.444823 [ 3849 ] {72a366ee-3eb8-494b-a3dc-0ec53ac1208b} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:33.103470 [ 3849 ] {eb3a9b1a-99bb-4db6-a0d1-bb2e4d30e765} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46846) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:33.107894 [ 3849 ] {eb3a9b1a-99bb-4db6-a0d1-bb2e4d30e765} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:33.227230 [ 2911 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:34.237884 [ 2890 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:35.256975 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:36.259966 [ 2848 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:36.470942 [ 4203 ] {53ad7538-7ead-4ea8-ac90-daab7addb4f3} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46850) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:36.473454 [ 4203 ] {53ad7538-7ead-4ea8-ac90-daab7addb4f3} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:37.266884 [ 2808 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:38.279114 [ 2787 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:39.281686 [ 2761 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:39.818213 [ 3748 ] {f8b7da1b-4755-40d4-b306-64883e9f2fbc} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46862) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DROP PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:39.819253 [ 3748 ] {f8b7da1b-4755-40d4-b306-64883e9f2fbc} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:40.293771 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:41.300382 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:42.306161 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:43.310896 [ 3174 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:43.426842 [ 3966 ] {de37b777-89bd-425c-be5f-568dd5606129} executeQuery: Code: 57. DB::Exception: Table test_myjw9yvt.src already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: /* ddl_entry=query-0000000007 */ CREATE TABLE test_myjw9yvt.src UUID 'b3272b5a-a213-4727-ba4f-9d8ab46e5a8d' (`p` UInt64, `k` String, `d` UInt64) ENGINE = MergeTree PARTITION BY p ORDER BY k SETTINGS index_granularity = 63339, min_bytes_for_wide_part = 51444114, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 410220602, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 6076801, merge_max_block_size = 19310, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 494588, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 6899992, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 96765, primary_key_compress_block_size = 15125), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:43.437677 [ 3966 ] {de37b777-89bd-425c-be5f-568dd5606129} executeQuery: Code: 57. DB::Exception: Table test_myjw9yvt.src already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58300) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: CREATE TABLE src (`p` UInt64, `k` String, `d` UInt64) ENGINE = MergeTree PARTITION BY p ORDER BY k SETTINGS index_granularity = 63339, min_bytes_for_wide_part = 51444114, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 410220602, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 6076801, merge_max_block_size = 19310, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 494588, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 6899992, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 96765, primary_key_compress_block_size = 15125), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:43.439136 [ 3966 ] {de37b777-89bd-425c-be5f-568dd5606129} TCPHandler: Code: 57. DB::Exception: Table test_myjw9yvt.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017676758 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000017673ee5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000017122f57 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000170f2a79 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c43ef6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:44.312850 [ 3147 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:44.640408 [ 3966 ] {a64d1f18-0bca-4d46-abd1-f436cd3b39e0} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58344) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: INSERT INTO dst_r1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:44.640901 [ 3966 ] {a64d1f18-0bca-4d46-abd1-f436cd3b39e0} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:45.317539 [ 3113 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:45.736594 [ 3966 ] {7615fd58-3e9c-416d-b464-32dd636aac31} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58370) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:45.737368 [ 3966 ] {7615fd58-3e9c-416d-b464-32dd636aac31} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:46.323304 [ 3094 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:47.327914 [ 3062 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:48.332740 [ 2689 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:49.179000 [ 3866 ] {bf45e3ca-f12e-4734-b57e-db648c84f803} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58372) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:49.179699 [ 3866 ] {bf45e3ca-f12e-4734-b57e-db648c84f803} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:49.337183 [ 3001 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:50.338131 [ 2983 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:51.339307 [ 2958 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:52.340311 [ 2929 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:52.586260 [ 3528 ] {2d94c004-86c6-438b-9716-85c732719a87} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49296) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:52.586969 [ 3528 ] {2d94c004-86c6-438b-9716-85c732719a87} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:52.672863 [ 3966 ] {515044ce-0796-4d34-8055-e130f9c7d2e9} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49280) (comment: 01760_system_dictionaries.sql) (in query: DROP DICTIONARY 01760_db.example_simple_key_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:52.674228 [ 3966 ] {515044ce-0796-4d34-8055-e130f9c7d2e9} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:53.273099 [ 3866 ] {318dc14f-45b4-4525-b1e2-209d1142912e} 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.10057.altinitytest (altinity build)) (from [::1]:49312) (comment: 01555_or_fill.sql) (in query: SELECT count(), countOrNull(), sum(x), sumOrNull(x) FROM ( SELECT number AS x FROM numbers(10) WHERE number > 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:53.278771 [ 3866 ] {318dc14f-45b4-4525-b1e2-209d1142912e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:53.342317 [ 2910 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:54.344984 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:55.346718 [ 2860 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:55.372540 [ 2875 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001769e9e7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000001769f17c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176aa3a2 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:55.939533 [ 3826 ] {d8b1081a-bbf9-4f27-9d23-8d7c33dcfd2e} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49342) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:55.940309 [ 3826 ] {d8b1081a-bbf9-4f27-9d23-8d7c33dcfd2e} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:56.348538 [ 2844 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:56.919509 [ 12087 ] {af96c4f4-3d2b-4617-8e3a-a97f6d5b2e4a} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:00:01: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:56.922895 [ 3528 ] {af96c4f4-3d2b-4617-8e3a-a97f6d5b2e4a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49354) (comment: 01259_dictionary_custom_settings_ddl.sql) (in query: SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:56.934464 [ 3528 ] {af96c4f4-3d2b-4617-8e3a-a97f6d5b2e4a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:56.958106 [ 3528 ] {0a1b60a0-5a07-467d-85e2-9b354f3e6caf} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49354) (comment: 01259_dictionary_custom_settings_ddl.sql) (in query: DROP DATABASE IF EXISTS ordinary_db;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:56.959412 [ 3528 ] {0a1b60a0-5a07-467d-85e2-9b354f3e6caf} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:57.350725 [ 2819 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:58.352493 [ 2798 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 18:59:59.332255 [ 3528 ] {36018d6e-d70a-4397-961c-286c5e90baac} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49418) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:59.333105 [ 3528 ] {36018d6e-d70a-4397-961c-286c5e90baac} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000001710d05c 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001710cbd4 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:119: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c1f0c2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 18:59:59.354701 [ 2774 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:00.317724 [ 3528 ] {a069cc9d-67f7-479a-9a68-d7cd4a1bc57f} executeQuery: Code: 497. DB::Exception: test_3_restricted_user_2477330219: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49476) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO table_with_default (key) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 25. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 26. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:00:00.319295 [ 3528 ] {a069cc9d-67f7-479a-9a68-d7cd4a1bc57f} TCPHandler: Code: 497. DB::Exception: test_3_restricted_user_2477330219: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 25. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 26. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:00:00.355781 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:01.360239 [ 2719 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:02.361726 [ 2707 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:02.672085 [ 5645 ] {} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:00:07: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:03.023829 [ 5779 ] {11e88e28-2e9c-4a63-83dd-291c0b13cd57} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d), uniqExact(_part) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57780) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d), uniqExact(_part) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:03.024909 [ 5779 ] {11e88e28-2e9c-4a63-83dd-291c0b13cd57} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d), uniqExact(_part) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:03.365327 [ 2691 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:03.397697 [ 5779 ] {187ed227-8a50-462e-9177-6ce320212a69} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57786) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:03.398458 [ 5779 ] {187ed227-8a50-462e-9177-6ce320212a69} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:04.306842 [ 5779 ] {023a7f73-0999-4415-bba9-cfb47747a778} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57788) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: OPTIMIZE TABLE dst_r1 PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:04.308006 [ 5779 ] {023a7f73-0999-4415-bba9-cfb47747a778} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:04.366861 [ 3163 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:05.375519 [ 3147 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:05.755241 [ 5636 ] {55d8194b-5c3b-4594-9936-4ec39cabc192} executeQuery: Code: 497. DB::Exception: test_3_restricted_user_2477330219: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO test_3.table_with_default (key) FORMAT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550f4a 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:00:05.757232 [ 5636 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_3.table_with_default (key) FORMAT Values': Code: 497. DB::Exception: test_3_restricted_user_2477330219: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550f4a 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:05.762654 [ 3528 ] {70054c63-b3b1-44c0-b36b-03548a05baae} executeQuery: Code: 497. DB::Exception: test_3_restricted_user_2477330219: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49482) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO table_with_default (key) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550f4a 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:00:05.772679 [ 3528 ] {70054c63-b3b1-44c0-b36b-03548a05baae} TCPHandler: Code: 497. DB::Exception: test_3_restricted_user_2477330219: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016717da0 5. ./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 @ 0x00000000167179a2 6. ./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 @ 0x0000000016716d8c 7. ./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 @ 0x00000000166f920a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000175a254d 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007b965c3 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b925f0 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbbb67 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000001a694611 18. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550f4a 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:00:06.380802 [ 3123 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:07.385953 [ 3098 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:07.732933 [ 4083 ] {5fe59dc3-c510-421a-a28c-0a0c200dd562} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57860) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: OPTIMIZE TABLE dst_r1 PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:07.733963 [ 4083 ] {5fe59dc3-c510-421a-a28c-0a0c200dd562} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:08.390800 [ 3192 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:09.393626 [ 3071 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:10.400700 [ 3040 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:11.176844 [ 4083 ] {b8eec0af-60f2-47de-adcd-41651b8686ba} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57914) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: OPTIMIZE TABLE dst_r1 PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:11.178155 [ 4083 ] {b8eec0af-60f2-47de-adcd-41651b8686ba} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:11.402534 [ 3020 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:12.405467 [ 2724 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:12.670550 [ 8719 ] {} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:00:21: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:13.289732 [ 4083 ] {d711bc1c-da1d-4c3e-bd12-204e7e6338e7} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35048) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: DROP DICTIONARY 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:13.291928 [ 4083 ] {d711bc1c-da1d-4c3e-bd12-204e7e6338e7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:13.408553 [ 3012 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:14.413401 [ 2968 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:14.608028 [ 4203 ] {5606e159-6296-4cd9-8543-7f1a6feb1eb6} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35100) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: OPTIMIZE TABLE dst_r1 PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:14.609189 [ 4203 ] {5606e159-6296-4cd9-8543-7f1a6feb1eb6} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:15.049481 [ 4083 ] {f6ffd43a-22fe-40f6-8693-aa470645e070} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=773): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35052) (comment: 03215_view_with_recursive.sql) (in query: SELECT * FROM 03215_test_v;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:128: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000001a9b71b9 9. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x000000001a9b6d71 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:15.099303 [ 4083 ] {f6ffd43a-22fe-40f6-8693-aa470645e070} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=773): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:128: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000001a9b71b9 9. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x000000001a9b6d71 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:15.145394 [ 3826 ] {d976243f-d82f-4f91-8ffc-e4e0c2d019c5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35054) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:15.146187 [ 3826 ] {d976243f-d82f-4f91-8ffc-e4e0c2d019c5} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:15.175686 [ 5779 ] {96999e35-520e-4cf9-a760-90c0f872cae1} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35070) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:15.177304 [ 5779 ] {96999e35-520e-4cf9-a760-90c0f872cae1} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:15.419178 [ 2943 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:15.784894 [ 4101 ] {cd5e7ad6-3bae-456f-a5d5-cdb543293ca2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35090) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:15.796366 [ 4101 ] {cd5e7ad6-3bae-456f-a5d5-cdb543293ca2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:16.203206 [ 3826 ] {4752c8c9-ae7e-4d14-86b0-da8e5f632ef5} executeQuery: Code: 1. DB::Exception: Experimental WINDOW VIEW feature is not supported in the current infrastructure for query analysis (the setting 'allow_experimental_analyzer'). (UNSUPPORTED_METHOD) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35054) (in query: CREATE WINDOW VIEW 01056_window_view_proc_hop_watch.wv ENGINE Memory AS SELECT count(a) AS count FROM 01056_window_view_proc_hop_watch.mt GROUP BY hop(timestamp, INTERVAL '1' SECOND, INTERVAL '1' SECOND, 'US/Samoa') AS wid;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:1767: DB::StorageWindowView::throwIfWindowViewIsDisabled(std::shared_ptr) const @ 0x0000000019ec54b7 5. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:0: DB::StorageWindowView::StorageWindowView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel) @ 0x0000000019ed4e40 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000019eedee3 7. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:1780: 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&) @ 0x0000000019ee39bd 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191ba866 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:16.204015 [ 3826 ] {4752c8c9-ae7e-4d14-86b0-da8e5f632ef5} TCPHandler: Code: 1. DB::Exception: Experimental WINDOW VIEW feature is not supported in the current infrastructure for query analysis (the setting 'allow_experimental_analyzer'). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:1767: DB::StorageWindowView::throwIfWindowViewIsDisabled(std::shared_ptr) const @ 0x0000000019ec54b7 5. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:0: DB::StorageWindowView::StorageWindowView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel) @ 0x0000000019ed4e40 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000019eedee3 7. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:1780: 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&) @ 0x0000000019ee39bd 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191ba866 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:16.320564 [ 3826 ] {14f8277d-089a-4d7d-af77-5d894a789654} executeQuery: Code: 60. DB::Exception: Table `01056_window_view_proc_hop_watch`.wv does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35054) (in query: WATCH 01056_window_view_proc_hop_watch.wv), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:0: DB::InterpreterWatchQuery::buildQueryPipeline() @ 0x00000000182ab48e 5. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:0: DB::InterpreterWatchQuery::execute() @ 0x00000000182aaee1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:16.321428 [ 3826 ] {14f8277d-089a-4d7d-af77-5d894a789654} TCPHandler: Code: 60. DB::Exception: Table `01056_window_view_proc_hop_watch`.wv does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:0: DB::InterpreterWatchQuery::buildQueryPipeline() @ 0x00000000182ab48e 5. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:0: DB::InterpreterWatchQuery::execute() @ 0x00000000182aaee1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:16.421129 [ 2927 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:16.937901 [ 4083 ] {01210479-b3c0-4218-97e4-0ee5cb072a14} 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.10057.altinitytest (altinity build)) (from [::1]:35106) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String const&, String&&) @ 0x00000000174d6ddc 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d2a41 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce641 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:16.938985 [ 4083 ] {01210479-b3c0-4218-97e4-0ee5cb072a14} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String const&, String&&) @ 0x00000000174d6ddc 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d2a41 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce641 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:17.423935 [ 2896 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:17.764944 [ 3273 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4223a3c0-8513-4832-8627-dc06e0ab4b90::20000101_20000101_1_6_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:18.071540 [ 3849 ] {2712335f-04a7-4a6f-a61e-8b3da919bd38} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35122) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: OPTIMIZE TABLE dst_r1 PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:18.072433 [ 3849 ] {2712335f-04a7-4a6f-a61e-8b3da919bd38} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:18.319205 [ 4083 ] {5aecd017-cad1-4db0-864e-d74c347ff817} 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.10057.altinitytest (altinity build)) (from [::1]:35112) (comment: 00311_array_primary_key.sql) (in query: ATTACH TABLE array_pk;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:18.321092 [ 4083 ] {5aecd017-cad1-4db0-864e-d74c347ff817} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:18.425353 [ 2873 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:19.131318 [ 4083 ] {d38590b5-2568-443e-865a-18aad19bf490} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(groupArray(9223372036854775807), UInt32) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: groupArray instead of groupArray. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35134) (comment: 01632_group_array_msan.sql) (in query: SELECT groupArrayMerge(1048577)(y * 1048576) FROM (SELECT groupArrayState(9223372036854775807)(x) AS y FROM (SELECT 1048576 AS x)) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000015e1d707 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b1e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000162292ab 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:19.132628 [ 4083 ] {d38590b5-2568-443e-865a-18aad19bf490} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(groupArray(9223372036854775807), UInt32) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: groupArray instead of groupArray. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000015e1d707 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b1e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000162292ab 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:19.427059 [ 2854 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:20.122354 [ 4083 ] {974ac56e-6b3a-440c-8eee-d9befe578ba6} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(quantileResample(0.1, 1, 2, 42), UInt64, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: quantileResample instead of quantileResample. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35134) (comment: 01632_group_array_msan.sql) (in query: SELECT quantileResampleMerge(0.5, 257, 65536, 1)(tuple(*).1) FROM (SELECT quantileResampleState(0.10, 1, 2, 42)(number, number) FROM numbers(100));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000015e1d707 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b1e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000162292ab 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:20.123260 [ 4083 ] {974ac56e-6b3a-440c-8eee-d9befe578ba6} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(quantileResample(0.1, 1, 2, 42), UInt64, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: quantileResample instead of quantileResample. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000015e1d707 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b1e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000162292ab 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:20.428264 [ 2832 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:21.429956 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:21.437791 [ 4083 ] {7aa45ae2-4e0a-497c-9d68-79a48ec112dc} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35150) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:21.439128 [ 4083 ] {7aa45ae2-4e0a-497c-9d68-79a48ec112dc} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r1 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:21.789993 [ 4083 ] {bdd77550-5f68-4264-9d82-9328dfe4fee7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d), uniqExact(_part) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35164) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d), uniqExact(_part) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:21.791253 [ 4083 ] {bdd77550-5f68-4264-9d82-9328dfe4fee7} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d), uniqExact(_part) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:22.431461 [ 2787 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:22.837848 [ 5641 ] {} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:00:35: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/b91/b91886da-ad1e-4525-a0eb-713f249e34c0/all_1_1_0/ in table test_15.table_for_dict (b91886da-ad1e-4525-a0eb-713f249e34c0) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d5c0b5 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5dad4 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5e04e 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fdcc4b 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 19. ./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>>&) @ 0x0000000019be070e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:22.986995 [ 4083 ] {b2d505dc-db94-4976-97bb-bb011770ebf8} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40414) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:22.988334 [ 4083 ] {b2d505dc-db94-4976-97bb-bb011770ebf8} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:23.357982 [ 4083 ] {657c3df8-1c30-41c5-8c9f-c642931c1f17} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d), uniqExact(_part) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40430) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d), uniqExact(_part) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:23.380913 [ 4083 ] {657c3df8-1c30-41c5-8c9f-c642931c1f17} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d), uniqExact(_part) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:23.432470 [ 2763 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:24.295155 [ 4083 ] {630dbad3-dd49-4acf-b03c-02ada73805cd} executeQuery: Code: 36. DB::Exception: Table test_myjw9yvt.dst_r1 is not replicated. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40460) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM RESTART REPLICA dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x00000000182655c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:703: DB::InterpreterSystemQuery::execute() @ 0x0000000018254ab6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:24.295868 [ 4083 ] {630dbad3-dd49-4acf-b03c-02ada73805cd} TCPHandler: Code: 36. DB::Exception: Table test_myjw9yvt.dst_r1 is not replicated. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x00000000182655c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:703: DB::InterpreterSystemQuery::execute() @ 0x0000000018254ab6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:24.433420 [ 2741 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:24.637257 [ 4083 ] {2b376779-25a5-48eb-a46e-9c4a0a16d31b} executeQuery: Code: 36. DB::Exception: Table test_myjw9yvt.dst_r2 is not replicated. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40462) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM RESTART REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x00000000182655c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:703: DB::InterpreterSystemQuery::execute() @ 0x0000000018254ab6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:24.638975 [ 4083 ] {2b376779-25a5-48eb-a46e-9c4a0a16d31b} TCPHandler: Code: 36. DB::Exception: Table test_myjw9yvt.dst_r2 is not replicated. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x00000000182655c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:703: DB::InterpreterSystemQuery::execute() @ 0x0000000018254ab6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:25.013289 [ 4083 ] {e03b9276-71b8-4ddf-94b0-09ae94ede18c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40472) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:25.013809 [ 4083 ] {e03b9276-71b8-4ddf-94b0-09ae94ede18c} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:25.375220 [ 4083 ] {128f8887-6a11-46e1-a90f-f3bb46089b6f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40486) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:25.378759 [ 4083 ] {128f8887-6a11-46e1-a90f-f3bb46089b6f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:25.435241 [ 2726 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:26.135101 [ 4083 ] {f717d98b-92a3-4a38-bca1-7437ec6a23a2} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40516) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:26.135713 [ 4083 ] {f717d98b-92a3-4a38-bca1-7437ec6a23a2} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:26.436309 [ 2687 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:27.437419 [ 3169 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:28.438432 [ 3131 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:29.439594 [ 3111 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:29.502412 [ 3849 ] {daf95a60-b5e4-48da-a1cb-8bfc3ec09f79} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40556) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:29.503152 [ 3849 ] {daf95a60-b5e4-48da-a1cb-8bfc3ec09f79} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:29.895382 [ 4083 ] {d1987452-b8ce-426b-b680-829ba4ec4c0b} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40524) (comment: 01710_projections.sql) (in query: select * from projection_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1f01 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:29.896276 [ 4083 ] {d1987452-b8ce-426b-b680-829ba4ec4c0b} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1f01 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:29.984118 [ 4101 ] {638bf016-af99-4cf4-a606-dc2f28b11073} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=761). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40568) (comment: 00498_array_functions_concat_slice_push_pop.sql) (in query: select arraySlice([1, 2, 3, 4, 5, 6], Null, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:29.984888 [ 4101 ] {638bf016-af99-4cf4-a606-dc2f28b11073} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=761). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:30.069157 [ 4083 ] {f0608dc4-9abb-464a-bdb9-b3fadee5f39e} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40524) (comment: 01710_projections.sql) (in query: select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) from projection_test join (select 1) x on 1 where domain = '1' group by dt_m order by dt_m;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Planner/PlannerJoins.cpp:894: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e12038 5. ./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&) @ 0x0000000017df0110 6. ./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&) @ 0x0000000017de0b12 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:30.070043 [ 4083 ] {f0608dc4-9abb-464a-bdb9-b3fadee5f39e} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Planner/PlannerJoins.cpp:894: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e12038 5. ./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&) @ 0x0000000017df0110 6. ./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&) @ 0x0000000017de0b12 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:30.440462 [ 3084 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:30.690452 [ 4083 ] {c430680a-8f09-4502-bb58-9247590fc3e2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40582) (comment: 01720_type_map_and_casts.sql) (in query: SELECT m FROM table_map_with_key_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016f5c727 13. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:0: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016fc7879 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:00:30.691799 [ 4083 ] {c430680a-8f09-4502-bb58-9247590fc3e2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016f5c727 13. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:0: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016fc7879 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:00:31.209079 [ 4083 ] {46885b2a-45dc-4b5b-8dc8-f204a085c37f} 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.10057.altinitytest (altinity build)) (from [::1]:40590) (comment: 02987_group_array_intersect.sql) (in query: SELECT groupArrayIntersect(*) FROM test_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.210436 [ 4083 ] {46885b2a-45dc-4b5b-8dc8-f204a085c37f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.441331 [ 2703 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:31.903101 [ 3849 ] {8c8bac52-c3e3-4b2a-ad05-3d99f571a558} executeQuery: Code: 36. DB::Exception: SELECT from system.zookeeper table must contain condition like path = 'path' or path IN ('path1','path2'...) or path IN (subquery) in WHERE clause unless `set allow_unrestricted_reads_from_keeper = 'true'`.: While executing SystemZooKeeper. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40626) (comment: 02976_system_zookeeper_filters.sql) (in query: SELECT count() > 0 FROM system.zookeeper;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:489: DB::SystemZooKeeperSource::generate() @ 0x00000000161f290f 5. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.903888 [ 3849 ] {8c8bac52-c3e3-4b2a-ad05-3d99f571a558} TCPHandler: Code: 36. DB::Exception: SELECT from system.zookeeper table must contain condition like path = 'path' or path IN ('path1','path2'...) or path IN (subquery) in WHERE clause unless `set allow_unrestricted_reads_from_keeper = 'true'`.: While executing SystemZooKeeper. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:489: DB::SystemZooKeeperSource::generate() @ 0x00000000161f290f 5. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.921141 [ 3849 ] {52ad38e9-e17b-44b7-9b2d-4ce0bcbbff4e} executeQuery: Code: 36. DB::Exception: SELECT from system.zookeeper table must contain condition like path = 'path' or path IN ('path1','path2'...) or path IN (subquery) in WHERE clause unless `set allow_unrestricted_reads_from_keeper = 'true'`.: While executing SystemZooKeeper. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40626) (comment: 02976_system_zookeeper_filters.sql) (in query: SELECT count() > 0 FROM system.zookeeper WHERE name LIKE '%_%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:489: DB::SystemZooKeeperSource::generate() @ 0x00000000161f290f 5. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.921844 [ 3849 ] {52ad38e9-e17b-44b7-9b2d-4ce0bcbbff4e} TCPHandler: Code: 36. DB::Exception: SELECT from system.zookeeper table must contain condition like path = 'path' or path IN ('path1','path2'...) or path IN (subquery) in WHERE clause unless `set allow_unrestricted_reads_from_keeper = 'true'`.: While executing SystemZooKeeper. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:489: DB::SystemZooKeeperSource::generate() @ 0x00000000161f290f 5. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.938877 [ 3849 ] {484dfe99-c138-443d-b401-b79b8fcb011f} executeQuery: Code: 36. DB::Exception: SELECT from system.zookeeper table must contain condition like path = 'path' or path IN ('path1','path2'...) or path IN (subquery) in WHERE clause unless `set allow_unrestricted_reads_from_keeper = 'true'`.: While executing SystemZooKeeper. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40626) (comment: 02976_system_zookeeper_filters.sql) (in query: SELECT count() > 0 FROM system.zookeeper WHERE value LIKE '%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:489: DB::SystemZooKeeperSource::generate() @ 0x00000000161f290f 5. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.939753 [ 3849 ] {484dfe99-c138-443d-b401-b79b8fcb011f} TCPHandler: Code: 36. DB::Exception: SELECT from system.zookeeper table must contain condition like path = 'path' or path IN ('path1','path2'...) or path IN (subquery) in WHERE clause unless `set allow_unrestricted_reads_from_keeper = 'true'`.: While executing SystemZooKeeper. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:489: DB::SystemZooKeeperSource::generate() @ 0x00000000161f290f 5. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.955836 [ 3849 ] {57234525-daea-4a0e-965d-ef0449c6b2b5} executeQuery: Code: 36. DB::Exception: SELECT from system.zookeeper table must contain condition like path = 'path' or path IN ('path1','path2'...) or path IN (subquery) in WHERE clause unless `set allow_unrestricted_reads_from_keeper = 'true'`.: While executing SystemZooKeeper. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40626) (comment: 02976_system_zookeeper_filters.sql) (in query: SELECT count() > 0 FROM system.zookeeper WHERE path LIKE '/%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:489: DB::SystemZooKeeperSource::generate() @ 0x00000000161f290f 5. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:31.956839 [ 3849 ] {57234525-daea-4a0e-965d-ef0449c6b2b5} TCPHandler: Code: 36. DB::Exception: SELECT from system.zookeeper table must contain condition like path = 'path' or path IN ('path1','path2'...) or path IN (subquery) in WHERE clause unless `set allow_unrestricted_reads_from_keeper = 'true'`.: While executing SystemZooKeeper. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:489: DB::SystemZooKeeperSource::generate() @ 0x00000000161f290f 5. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:32.080027 [ 3849 ] {d37dc9ff-8ce9-460e-a0af-5d5f3d0ad21e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=761). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40626) (comment: 02976_system_zookeeper_filters.sql) (in query: SELECT count() > 0 FROM system.zookeeper;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:32.080415 [ 3849 ] {d37dc9ff-8ce9-460e-a0af-5d5f3d0ad21e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=761). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:32.442345 [ 3076 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:32.722792 [ 4083 ] {8cc7a4ff-ff67-4570-af8b-a5a63c8618ad} executeQuery: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007965927 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000000796556b 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&&) @ 0x00000000079578bd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:32.723690 [ 4083 ] {8cc7a4ff-ff67-4570-af8b-a5a63c8618ad} TCPHandler: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007965927 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000000796556b 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&&) @ 0x00000000079578bd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:32.734935 [ 4083 ] {3dc043cb-7b1b-43f2-a164-6f67a6deb4f6} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007965927 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000000796556b 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&&) @ 0x00000000079578bd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:32.735935 [ 4083 ] {3dc043cb-7b1b-43f2-a164-6f67a6deb4f6} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007965927 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000000796556b 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&&) @ 0x00000000079578bd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:32.911421 [ 3849 ] {44cd14c2-2330-4caa-b6d6-3c7abd53cb44} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36430) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:32.911994 [ 3849 ] {44cd14c2-2330-4caa-b6d6-3c7abd53cb44} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:32.985149 [ 4083 ] {11bd32e2-9315-456c-841b-35cbae55780a} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000000796472c 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000079643d1 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&&) @ 0x0000000007950964 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:32.985914 [ 4083 ] {11bd32e2-9315-456c-841b-35cbae55780a} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000000796472c 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000079643d1 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&&) @ 0x0000000007950964 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:32.992697 [ 4083 ] {aef046d4-9c31-4536-8945-d91f2ce57ae6} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000000796472c 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000079643d1 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&&) @ 0x0000000007950964 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:32.993266 [ 4083 ] {aef046d4-9c31-4536-8945-d91f2ce57ae6} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000000796472c 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000079643d1 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&&) @ 0x0000000007950964 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:33.257440 [ 4083 ] {f647dfb3-814c-4f94-abb5-737fbbe23289} executeQuery: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate('2149-06-06'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x0000000007b610c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007963570 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007963211 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&&) @ 0x00000000079508e0 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:33.258940 [ 4083 ] {f647dfb3-814c-4f94-abb5-737fbbe23289} TCPHandler: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x0000000007b610c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007963570 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007963211 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&&) @ 0x00000000079508e0 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:33.443290 [ 2720 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:33.601375 [ 4083 ] {b7e1b4bb-b63a-4657-814f-34a63e0d43e0} executeQuery: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x0000000007b75f71 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x0000000007b75be1 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&&) @ 0x0000000007a80cbd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:33.602342 [ 4083 ] {b7e1b4bb-b63a-4657-814f-34a63e0d43e0} TCPHandler: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x0000000007b75f71 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x0000000007b75be1 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&&) @ 0x0000000007a80cbd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:33.610831 [ 4083 ] {adf65b83-11c8-4e08-9b49-258963fb0d5b} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x0000000007b75f71 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x0000000007b75be1 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&&) @ 0x0000000007a80cbd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:33.611711 [ 4083 ] {adf65b83-11c8-4e08-9b49-258963fb0d5b} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x0000000007b75f71 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x0000000007b75be1 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&&) @ 0x0000000007a80cbd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:34.173629 [ 4083 ] {9c5798b5-2a13-4ce2-841f-a4085d6b1d64} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007b73b0e 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007b737e4 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&&) @ 0x0000000007a7a579 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:34.174747 [ 4083 ] {9c5798b5-2a13-4ce2-841f-a4085d6b1d64} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007b73b0e 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007b737e4 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&&) @ 0x0000000007a7a579 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:34.184897 [ 4083 ] {52b9234a-d29b-410f-94fb-b1a381fecb22} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36412) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007b73b0e 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007b737e4 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&&) @ 0x0000000007a7a579 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:34.186087 [ 4083 ] {52b9234a-d29b-410f-94fb-b1a381fecb22} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007b73b0e 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007b737e4 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&&) @ 0x0000000007a7a579 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:00:34.444458 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:34.662930 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_1_60_19}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:35.445430 [ 3002 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:36.273519 [ 4083 ] {80adf946-3880-4c1a-8056-b9c8d658cb42} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36460) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:36.274163 [ 4083 ] {80adf946-3880-4c1a-8056-b9c8d658cb42} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:36.446943 [ 2934 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:37.447973 [ 2916 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:37.685979 [ 12437 ] {} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:00:57: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:38.448902 [ 2889 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:38.660601 [ 4083 ] {a04abd0e-f2f1-4ee6-8352-aa2f1a4207a3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36468) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:38.661403 [ 4083 ] {a04abd0e-f2f1-4ee6-8352-aa2f1a4207a3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:39.297671 [ 4083 ] {6aa647b4-e3da-408a-95a7-7c28cdb85fee} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36480) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:39.299327 [ 4083 ] {6aa647b4-e3da-408a-95a7-7c28cdb85fee} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:39.449933 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:39.673768 [ 4083 ] {3e04f302-0f69-4895-958b-ab341d9ccff1} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36496) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:39.674402 [ 4083 ] {3e04f302-0f69-4895-958b-ab341d9ccff1} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:40.451120 [ 2855 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:41.361016 [ 4101 ] {cd5ffe2c-5a1e-4cd6-a408-65b46047959b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36504) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:41.362078 [ 4101 ] {cd5ffe2c-5a1e-4cd6-a408-65b46047959b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:41.452162 [ 2839 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:42.370175 [ 3275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {efc9ab92-e475-4973-9a01-6dd22a9c9450::202506_1_54_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:42.453245 [ 2815 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:43.104669 [ 4101 ] {dde11535-216b-474e-bc2d-eb041506566f} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46830) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:43.105395 [ 4101 ] {dde11535-216b-474e-bc2d-eb041506566f} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:43.454338 [ 2794 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:44.455791 [ 2777 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:44.476396 [ 4083 ] {b0fc0c89-08ad-4f5e-ae46-e3ad38b0eefd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36516) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:44.477596 [ 4083 ] {b0fc0c89-08ad-4f5e-ae46-e3ad38b0eefd} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:45.456826 [ 3107 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:46.444506 [ 4083 ] {5c51d392-4d8a-4873-b7c0-1a16fb3af759} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46844) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:46.446997 [ 4083 ] {5c51d392-4d8a-4873-b7c0-1a16fb3af759} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:46.458260 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:46.519645 [ 4083 ] {bb3fdbdc-3091-4ee6-8836-d3e2628825ed} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46856) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:46.520379 [ 4083 ] {bb3fdbdc-3091-4ee6-8836-d3e2628825ed} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:47.276067 [ 4083 ] {5dc4a91a-aa29-464e-9650-0be2c0aaa420} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46862) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:47.277565 [ 4083 ] {5dc4a91a-aa29-464e-9650-0be2c0aaa420} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:47.501493 [ 2727 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:47.947927 [ 4083 ] {fbfb461f-6776-445e-8edd-0727c2979177} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46868) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:47.949005 [ 4083 ] {fbfb461f-6776-445e-8edd-0727c2979177} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:48.288197 [ 4083 ] {959049ff-3373-40e0-a284-b5002686391d} 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.10057.altinitytest (altinity build)) (from [::1]:46876) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:48.289074 [ 4083 ] {959049ff-3373-40e0-a284-b5002686391d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:48.502314 [ 2702 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:49.276608 [ 4083 ] {98ffac4f-c36d-452f-861f-62492d5ea29b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46890) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:49.277797 [ 4083 ] {98ffac4f-c36d-452f-861f-62492d5ea29b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:49.503247 [ 3178 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:49.970402 [ 4101 ] {2cb31266-8107-4e50-822b-f235c8a501d2} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46902) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:49.971185 [ 4101 ] {2cb31266-8107-4e50-822b-f235c8a501d2} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:50.163985 [ 4083 ] {60ff69ec-33fb-476b-87f9-6b9a71134c43} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46896) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:50.164919 [ 4083 ] {60ff69ec-33fb-476b-87f9-6b9a71134c43} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:50.505169 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:51.506151 [ 3142 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:52.507074 [ 3118 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:53.319784 [ 4083 ] {4b9e0931-cef3-44c5-82ff-887e8be6a0b7} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39538) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:53.320188 [ 4083 ] {4b9e0931-cef3-44c5-82ff-887e8be6a0b7} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:53.507961 [ 3099 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:53.877015 [ 4083 ] {3b1c44bc-9986-4d36-8cd0-eebf9e4bf4bd} executeQuery: Code: 354. DB::Exception: inflate failed: data error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZLIB_INFLATE_FAILED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39550) (comment: 02724_decompress_filename_exception.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'gzip')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000fed9266 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:0: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x000000000fed8f5d 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:53.878743 [ 4083 ] {3b1c44bc-9986-4d36-8cd0-eebf9e4bf4bd} TCPHandler: Code: 354. DB::Exception: inflate failed: data error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZLIB_INFLATE_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000fed9266 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:0: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x000000000fed8f5d 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:54.390447 [ 4083 ] {a0496b65-23f5-439c-ae6c-2572620c7a7d} executeQuery: Code: 354. DB::Exception: inflate failed: data error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZLIB_INFLATE_FAILED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39560) (comment: 02724_decompress_filename_exception.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'deflate')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000fed9266 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:0: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x000000000fed8f5d 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:54.392386 [ 4083 ] {a0496b65-23f5-439c-ae6c-2572620c7a7d} TCPHandler: Code: 354. DB::Exception: inflate failed: data error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZLIB_INFLATE_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000fed9266 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:0: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x000000000fed8f5d 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:54.508871 [ 3086 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:55.220027 [ 4083 ] {ccfb3720-5b7d-43c0-94c7-a94e32a71a32} executeQuery: Code: 448. DB::Exception: brotli decode error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (BROTLI_READ_FAILED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39566) (comment: 02724_decompress_filename_exception.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'br')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/IO/BrotliReadBuffer.cpp:0: DB::BrotliReadBuffer::nextImpl() @ 0x000000000feda414 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:55.222087 [ 4083 ] {ccfb3720-5b7d-43c0-94c7-a94e32a71a32} TCPHandler: Code: 448. DB::Exception: brotli decode error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (BROTLI_READ_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/IO/BrotliReadBuffer.cpp:0: DB::BrotliReadBuffer::nextImpl() @ 0x000000000feda414 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:55.509749 [ 3069 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:55.865671 [ 4101 ] {d592213e-8f5b-460d-8ed2-d90fdd85d9e8} executeQuery: Code: 554. DB::Exception: lzma_stream_decoder failed: error code: error code LZMA_FORMAT_ERROR; lzma version: 5.3.1alpha: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (LZMA_STREAM_DECODER_FAILED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39608) (comment: 02724_decompress_filename_exception.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'xz')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, lzma_ret&, char const (&) [11], String&&) @ 0x000000000fedb50c 4. ./build_docker/./src/IO/LZMAInflatingReadBuffer.cpp:0: DB::LZMAInflatingReadBuffer::nextImpl() @ 0x000000000fedb2d5 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:55.925940 [ 4101 ] {d592213e-8f5b-460d-8ed2-d90fdd85d9e8} TCPHandler: Code: 554. DB::Exception: lzma_stream_decoder failed: error code: error code LZMA_FORMAT_ERROR; lzma version: 5.3.1alpha: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (LZMA_STREAM_DECODER_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, lzma_ret&, char const (&) [11], String&&) @ 0x000000000fedb50c 4. ./build_docker/./src/IO/LZMAInflatingReadBuffer.cpp:0: DB::LZMAInflatingReadBuffer::nextImpl() @ 0x000000000fedb2d5 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:55.995245 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3655178d-96ea-42c6-867f-61b9ceac796e::202506_1_46_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:56.511318 [ 3026 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:56.690650 [ 4203 ] {17c8a8d5-7356-4613-9bcc-c343445e5377} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39638) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:56.691216 [ 4203 ] {17c8a8d5-7356-4613-9bcc-c343445e5377} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:56.841885 [ 4101 ] {aa457a06-36c8-43cd-9486-e9121a466ae8} executeQuery: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Unknown frame descriptor'; ZSTD version: 1.5.5: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZSTD_DECODER_FAILED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39624) (comment: 02724_decompress_filename_exception.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'zstd')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x000000000fac7a54 4. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:0: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x000000000fac780f 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:56.844933 [ 4101 ] {aa457a06-36c8-43cd-9486-e9121a466ae8} TCPHandler: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Unknown frame descriptor'; ZSTD version: 1.5.5: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZSTD_DECODER_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x000000000fac7a54 4. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:0: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x000000000fac780f 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:57.512078 [ 3001 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:57.707905 [ 8297 ] {} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:01:16: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:57.731268 [ 4101 ] {107646d0-f41a-47fe-895a-e16c4fbe1a3a} executeQuery: Code: 618. DB::Exception: LZ4 decompression failed. LZ4F version: 100. Error: ERROR_frameType_unknown: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (LZ4_DECODER_FAILED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39644) (comment: 02724_decompress_filename_exception.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'lz4')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&&, char const*&&, String&&) @ 0x000000000fede9ac 4. ./build_docker/./src/IO/Lz4InflatingReadBuffer.cpp:0: DB::Lz4InflatingReadBuffer::nextImpl() @ 0x000000000fede784 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:57.732826 [ 4101 ] {107646d0-f41a-47fe-895a-e16c4fbe1a3a} TCPHandler: Code: 618. DB::Exception: LZ4 decompression failed. LZ4F version: 100. Error: ERROR_frameType_unknown: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (LZ4_DECODER_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&&, char const*&&, String&&) @ 0x000000000fede9ac 4. ./build_docker/./src/IO/Lz4InflatingReadBuffer.cpp:0: DB::Lz4InflatingReadBuffer::nextImpl() @ 0x000000000fede784 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:58.212651 [ 4101 ] {31f4e7e9-003c-406d-9fc3-21417356c843} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39650) (comment: 02724_decompress_filename_exception.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'bz2')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:58.213882 [ 4101 ] {31f4e7e9-003c-406d-9fc3-21417356c843} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:58.512770 [ 3012 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:58.908937 [ 4203 ] {61d16ca5-35d5-4bd8-afd0-9fd47ca44040} executeQuery: Code: 638. DB::Exception: hadoop snappy decode error: TOO_LARGE_COMPRESSED_BLOCK: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (SNAPPY_UNCOMPRESS_FAILED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39662) (comment: 02724_decompress_filename_exception.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'snappy')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/IO/HadoopSnappyReadBuffer.cpp:0: DB::HadoopSnappyReadBuffer::nextImpl() @ 0x000000000fedda38 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:58.911671 [ 4203 ] {61d16ca5-35d5-4bd8-afd0-9fd47ca44040} TCPHandler: Code: 638. DB::Exception: hadoop snappy decode error: TOO_LARGE_COMPRESSED_BLOCK: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (SNAPPY_UNCOMPRESS_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/IO/HadoopSnappyReadBuffer.cpp:0: DB::HadoopSnappyReadBuffer::nextImpl() @ 0x000000000fedda38 5. DB::ReadBuffer::next() @ 0x0000000007b3417b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fac26fc 7. DB::ReadBuffer::next() @ 0x0000000007b3417b 8. ./src/IO/ReadBuffer.h:0: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001a3b7286 9. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a38b5fb 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191cae64 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:00:59.513762 [ 2969 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:00:59.535587 [ 4203 ] {0bf08d0f-8fe9-43ac-94df-58f850118c0f} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitAnd(0, inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000008a1e93e 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000089538bc 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:00:59.536142 [ 4203 ] {0bf08d0f-8fe9-43ac-94df-58f850118c0f} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(0, inf). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000008a1e93e 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000089538bc 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:00:59.819833 [ 4203 ] {a27d8e71-937f-4ecd-9717-879a26e7302a} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitXor: In scope SELECT bitXor(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitXor(0, inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000940d67e 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000933f5bc 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:00:59.820517 [ 4203 ] {a27d8e71-937f-4ecd-9717-879a26e7302a} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitXor: In scope SELECT bitXor(0, inf). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000940d67e 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000933f5bc 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:00.033685 [ 3528 ] {e3c54adc-1205-46ee-a155-08648bf05efd} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39684) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:00.034335 [ 3528 ] {e3c54adc-1205-46ee-a155-08648bf05efd} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:00.290833 [ 4203 ] {8f128ae4-b726-4d7f-a0f0-cc259a420b0f} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitOr: In scope SELECT bitOr(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitOr(0, inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000008e28a5e 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000008d5a99c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:00.291600 [ 4203 ] {8f128ae4-b726-4d7f-a0f0-cc259a420b0f} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitOr: In scope SELECT bitOr(0, inf). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000008e28a5e 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000008d5a99c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:00.514707 [ 2947 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:00.566031 [ 4203 ] {f85898e9-8aa8-41ba-9de5-b74d3f0982b0} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitTest(inf, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000092fddbe 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000926045c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:00.566778 [ 4203 ] {f85898e9-8aa8-41ba-9de5-b74d3f0982b0} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000092fddbe 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000926045c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:00.572856 [ 4203 ] {784e3a5e-2d54-4993-8d0d-5d62dcf11e4d} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitTest: In scope SELECT bitTest(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitTest(0, inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000092fddbe 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000926045c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:00.573993 [ 4203 ] {784e3a5e-2d54-4993-8d0d-5d62dcf11e4d} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitTest: In scope SELECT bitTest(0, inf). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000092fddbe 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000926045c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:00.879589 [ 4203 ] {a8d15187-a171-4111-948b-b01483fb0aca} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitRotateLeft(inf, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000008f25c3e 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000008e4473c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:00.880265 [ 4203 ] {a8d15187-a171-4111-948b-b01483fb0aca} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000008f25c3e 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000008e4473c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:01.244635 [ 4203 ] {d7dd2a2a-3833-444b-81b4-e1a1bfffeb44} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateRight: In scope SELECT bitRotateRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitRotateRight(inf, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000009022cbe 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000008f4171c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:01.245330 [ 4203 ] {d7dd2a2a-3833-444b-81b4-e1a1bfffeb44} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateRight: In scope SELECT bitRotateRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000009022cbe 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000008f4171c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:01.460909 [ 4203 ] {b4e28745-fb0f-4f92-9e6f-b56a946496bc} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitShiftLeft(inf, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000912a6de 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000903e79c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:01.461626 [ 4203 ] {b4e28745-fb0f-4f92-9e6f-b56a946496bc} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000912a6de 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000903e79c 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:01.515478 [ 2984 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:01.686843 [ 4203 ] {4c8b73e1-301e-4eef-89b9-e4cb79de45dd} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftRight: In scope SELECT bitShiftRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39668) (comment: 01677_bit_float.sql) (in query: SELECT bitShiftRight(inf, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000922bbbe 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000009146dbc 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:01.687708 [ 4203 ] {4c8b73e1-301e-4eef-89b9-e4cb79de45dd} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftRight: In scope SELECT bitShiftRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000922bbbe 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000009146dbc 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008216661 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:02.516386 [ 2920 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:03.486833 [ 4203 ] {91e635c5-1e12-4184-9291-c867d3ec0e7e} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57166) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:03.487473 [ 4203 ] {91e635c5-1e12-4184-9291-c867d3ec0e7e} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:03.517078 [ 2912 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:04.517821 [ 2885 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:05.519266 [ 3170 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:06.520058 [ 2855 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:06.816869 [ 4203 ] {5a00a291-e58d-4188-babc-c24efa53d4a3} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57200) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:06.817430 [ 4203 ] {5a00a291-e58d-4188-babc-c24efa53d4a3} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:07.520970 [ 2839 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:08.521801 [ 2831 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:09.523440 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:10.147266 [ 4203 ] {ce43423e-8877-4256-9319-cfb2fc1f6c39} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57258) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:10.149458 [ 4203 ] {ce43423e-8877-4256-9319-cfb2fc1f6c39} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:10.524401 [ 2788 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:11.032435 [ 4203 ] {cbf6058f-42dc-46c9-b339-1ef6d9235f3d} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt8(1)). (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57260) (comment: 00800_function_java_hash_with_unsigined_types.sh) (in query: SELECT javaHash(toUInt8(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e72fb6 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e7232c 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000007e71c1c 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e716ea 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007be237c 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e712de 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 19:01:11.033576 [ 4203 ] {cbf6058f-42dc-46c9-b339-1ef6d9235f3d} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt8(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e72fb6 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e7232c 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000007e71c1c 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e716ea 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007be237c 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e712de 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 19:01:11.525206 [ 2774 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:11.884851 [ 4203 ] {b647f8ff-fe71-4ddf-9781-295eb0c451b5} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt16(1)). (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57294) (comment: 00800_function_java_hash_with_unsigined_types.sh) (in query: SELECT javaHash(toUInt16(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e7337a 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e7247a 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000007e71c1c 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e716ea 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007be237c 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e712de 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 19:01:11.885843 [ 4203 ] {b647f8ff-fe71-4ddf-9781-295eb0c451b5} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt16(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e7337a 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e7247a 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000007e71c1c 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e716ea 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007be237c 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e712de 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 19:01:12.526373 [ 2753 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:12.569345 [ 4203 ] {7135486d-e8bf-465c-828d-c4648b0b3b10} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt32(1)). (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44250) (comment: 00800_function_java_hash_with_unsigined_types.sh) (in query: SELECT javaHash(toUInt32(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e7373a 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e72422 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000007e71c1c 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e716ea 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007be237c 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e712de 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 19:01:12.570342 [ 4203 ] {7135486d-e8bf-465c-828d-c4648b0b3b10} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt32(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e7373a 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e72422 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000007e71c1c 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e716ea 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007be237c 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e712de 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 19:01:13.482575 [ 5737 ] {fc60d58e-3ecf-43ff-84e1-59c16b2f87ab} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44302) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 DETACH PARTITION 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:13.482968 [ 5737 ] {fc60d58e-3ecf-43ff-84e1-59c16b2f87ab} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:13.536533 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:13.566740 [ 4203 ] {4640a858-b62e-4567-baac-7ce253edb30d} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt64(1)). (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44274) (comment: 00800_function_java_hash_with_unsigined_types.sh) (in query: SELECT javaHash(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e73afa 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e724ec 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000007e71c1c 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e716ea 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007be237c 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e712de 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 19:01:13.567853 [ 4203 ] {4640a858-b62e-4567-baac-7ce253edb30d} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt64(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e73afa 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000007e724ec 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000007e71c1c 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e716ea 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007be237c 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e712de 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 2025.06.12 19:01:14.537171 [ 2728 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:15.192201 [ 4203 ] {dcb7069d-7b92-476b-bceb-a4fae23c6d78} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=758). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44348) (comment: 00147_alter_nested_default.sql) (in query: SELECT * FROM alter_00147 ARRAY JOIN n WHERE n.x LIKE '%Hello%' ORDER BY n.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:15.194091 [ 4203 ] {dcb7069d-7b92-476b-bceb-a4fae23c6d78} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=758). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:15.537959 [ 2705 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:16.133330 [ 4203 ] {69722ab7-6d30-4725-a276-47b854d4a57a} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44356) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: ALTER TABLE replicated_table_for_alter1 MODIFY SETTING index_granularity = 4096;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199df458 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:16.134438 [ 4203 ] {69722ab7-6d30-4725-a276-47b854d4a57a} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199df458 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:16.539391 [ 3137 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:16.568473 [ 4203 ] {ec797aa4-7b8e-44f6-8365-e68b86299bd8} 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.10057.altinitytest (altinity build)) (from [::1]:44356) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: SELECT COUNT() FROM replicated_table_for_alter2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:16.569751 [ 4203 ] {ec797aa4-7b8e-44f6-8365-e68b86299bd8} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:16.834746 [ 4203 ] {3f796eaf-003c-46cf-a72b-adf7e1629608} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44358) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 ATTACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:16.835334 [ 4203 ] {3f796eaf-003c-46cf-a72b-adf7e1629608} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:17.540526 [ 3116 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:17.737241 [ 8720 ] {} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:02:01: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:18.541659 [ 3087 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:19.542755 [ 3058 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:20.201034 [ 5737 ] {fc5b9961-9364-4686-a0ab-51d2a42730c9} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44396) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 ATTACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:20.201520 [ 5737 ] {fc5b9961-9364-4686-a0ab-51d2a42730c9} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:20.543603 [ 2689 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:21.544342 [ 2720 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:22.545673 [ 2999 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:23.023766 [ 3528 ] {ed79c4f9-3431-493f-9fd0-54f556ad5e45} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44422) (comment: 01660_join_or_any.sql) (in query: select a1 from tab1 any left join tab2 on b1 + 1 = a2 + 1 or a1 + 4 = b2 + 2 ORDER BY a1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 2025.06.12 19:01:23.027127 [ 3528 ] {ed79c4f9-3431-493f-9fd0-54f556ad5e45} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 2025.06.12 19:01:23.546567 [ 2941 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:23.600336 [ 5737 ] {c7c253f9-f4ae-4542-ad22-b47b7749bed5} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52684) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 ATTACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:23.600736 [ 5737 ] {c7c253f9-f4ae-4542-ad22-b47b7749bed5} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:24.547328 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:25.548747 [ 3145 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:26.550083 [ 2829 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:26.945258 [ 5737 ] {8eabf123-2dfa-400f-a5bd-4cbe174eaf33} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52696) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 ATTACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:26.945753 [ 5737 ] {8eabf123-2dfa-400f-a5bd-4cbe174eaf33} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:27.551616 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:28.553099 [ 2766 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:29.553903 [ 2735 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:30.264827 [ 5737 ] {c1a9a40e-f526-49f7-952a-00741135f0be} executeQuery: Code: 60. DB::Exception: Could not find table: dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52708) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: ALTER TABLE dst_r1 ATTACH PARTITION 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:30.265267 [ 5737 ] {c1a9a40e-f526-49f7-952a-00741135f0be} TCPHandler: Code: 60. DB::Exception: Could not find table: dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:30.555114 [ 2699 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:31.358963 [ 3966 ] {446ac0f1-ec84-4ef2-9a4e-8f508a05547c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.056700364 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49324) (comment: 00927_asof_join_long.sql) (in query: SELECT SUM(trades.price - tvs.tv) FROM (SELECT k, t, t as price FROM (SELECT toUInt32(number) AS k FROM numbers(1000)) keys CROSS JOIN (SELECT toUInt32(number * 10) AS t FROM numbers(3000)) trade_times SETTINGS join_algorithm = 'hash') trades ASOF LEFT JOIN tvs USING(k,t) SETTINGS join_algorithm = 'full_sorting_merge';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfd406 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfc526 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edeb41 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e19a8 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e15e8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007f4e69e13ac3 13. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:31.458991 [ 3966 ] {446ac0f1-ec84-4ef2-9a4e-8f508a05547c} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.056700364 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfd406 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfc526 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edeb41 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e19a8 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e15e8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007f4e69e13ac3 13. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:31.556254 [ 3158 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:31.609539 [ 3866 ] {199458ff-b4db-42c0-8ab3-8521f07fb940} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39618) (comment: 00927_asof_join_long.sql) (in query: DROP DATABASE IF EXISTS test_6pub8aoc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:31.611063 [ 3866 ] {199458ff-b4db-42c0-8ab3-8521f07fb940} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:32.486029 [ 3528 ] {30cd692b-0974-4b0d-9738-42d1fa2549ff} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52702) (comment: 02131_used_row_policies_in_query_log.sql) (in query: SELECT query, used_row_policies FROM system.query_log WHERE current_database == currentDatabase() AND type == 'QueryStart' AND query_kind == 'Select' ORDER BY event_time_microseconds;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:32.491605 [ 3528 ] {30cd692b-0974-4b0d-9738-42d1fa2549ff} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:32.557380 [ 3123 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:33.558168 [ 3096 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:33.626811 [ 3849 ] {279c9e91-c3ee-4158-87b3-99396a1ccd59} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58016) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:33.627682 [ 3849 ] {279c9e91-c3ee-4158-87b3-99396a1ccd59} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:33.975092 [ 3849 ] {bfea3815-dad0-49a7-b534-7e64d64401ea} executeQuery: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58036) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SYSTEM SYNC REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:33.975568 [ 3849 ] {bfea3815-dad0-49a7-b534-7e64d64401ea} TCPHandler: Code: 60. DB::Exception: Table test_myjw9yvt.dst_r2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000018260dc3 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:34.326347 [ 3849 ] {9c1c24ee-8fb1-43e4-a56d-0911cd02ea5c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58048) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:34.327110 [ 3849 ] {9c1c24ee-8fb1-43e4-a56d-0911cd02ea5c} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:34.558985 [ 3061 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:35.559888 [ 3020 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:35.576002 [ 5737 ] {b556bf30-ccd0-45d3-92b2-bc319128af74} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52012) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_myjw9yvt ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.576792 [ 5737 ] {b556bf30-ccd0-45d3-92b2-bc319128af74} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:35.585348 [ 3849 ] {b109fc84-afd3-45fc-8d54-e419ed42faf0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52022) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_myjw9yvt ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.586316 [ 3849 ] {b109fc84-afd3-45fc-8d54-e419ed42faf0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:35.600047 [ 5737 ] {e99ff36d-7cd0-4f70-b5c8-7a23a05eecf2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52036) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_myjw9yvt ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.600881 [ 5737 ] {e99ff36d-7cd0-4f70-b5c8-7a23a05eecf2} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:35.774451 [ 3528 ] {4316f2a6-63c8-4f53-961e-8ba3b4a48d95} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58068) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: CREATE TABLE table_for_dict1 (`key_column` UInt64, `value_column` String) ENGINE = MergeTree ORDER BY key_column SETTINGS index_granularity = 58478, 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 = 481208528, compact_parts_max_bytes_to_buffer = 157702297, compact_parts_max_granules_to_buffer = 237, compact_parts_merge_max_bytes_to_prefetch_part = 11859207, merge_max_block_size = 2414, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5056830256, index_granularity_bytes = 28228801, concurrent_part_removal_threshold = 28, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 13865, primary_key_compress_block_size = 49967), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.776079 [ 3528 ] {4316f2a6-63c8-4f53-961e-8ba3b4a48d95} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.956629 [ 5737 ] {953cfd2d-fc1c-4608-b628-621b6d89bdd4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:fccde7b1-af7b-48a0-af5c-066c77f1e3d4'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52046) (comment: 02845_table_function_hdfs_filter_by_virtual_columns.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ha1ro2iw ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.958239 [ 5737 ] {953cfd2d-fc1c-4608-b628-621b6d89bdd4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:fccde7b1-af7b-48a0-af5c-066c77f1e3d4'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:35.969163 [ 5737 ] {66384f4b-f929-4354-96a8-e1c530bbe214} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:6d5619d6-91e0-4db0-a4ee-86d67c1787fb'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52080) (comment: 01516_drop_table_stress_long.sh) (in query: CREATE DATABASE IF NOT EXISTS test_9gqbxe4f ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.970253 [ 5737 ] {66384f4b-f929-4354-96a8-e1c530bbe214} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:6d5619d6-91e0-4db0-a4ee-86d67c1787fb'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:35.980744 [ 5737 ] {e8c07adb-4f39-4f14-a542-e20d93025f63} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:d023a5f1-a5d2-4fab-ad12-d877b36e5541'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52092) (comment: 01035_prewhere_with_alias.sql) (in query: CREATE DATABASE IF NOT EXISTS test_a9zby8cp ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.981902 [ 5737 ] {e8c07adb-4f39-4f14-a542-e20d93025f63} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:d023a5f1-a5d2-4fab-ad12-d877b36e5541'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:35.996015 [ 3528 ] {e2ef4796-7112-474a-86b5-88ed269ead88} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:5215108b-0add-4ce4-84a6-531a27fc278b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52094) (comment: 00702_join_on_dups.sql) (in query: CREATE DATABASE IF NOT EXISTS test_y705mr1p ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:35.997478 [ 3528 ] {e2ef4796-7112-474a-86b5-88ed269ead88} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:5215108b-0add-4ce4-84a6-531a27fc278b'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.018265 [ 3528 ] {15d014f8-1225-44e9-b962-0c60ecee8aa2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:e512abe1-3324-4dfc-865c-06a58e4067c5'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52102) (comment: 03313_case_insensitive_json_type_declaration.sql) (in query: CREATE DATABASE IF NOT EXISTS test_k3i3oswc ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.019621 [ 3528 ] {15d014f8-1225-44e9-b962-0c60ecee8aa2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:e512abe1-3324-4dfc-865c-06a58e4067c5'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.134682 [ 3528 ] {6f9a4171-df2e-440c-8874-e6945ddb911e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:d9d48c0c-08ab-40bc-82a0-b0f694e7994b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52114) (comment: 02884_parallel_window_functions_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lnfgog8h ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.136065 [ 3528 ] {6f9a4171-df2e-440c-8874-e6945ddb911e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:d9d48c0c-08ab-40bc-82a0-b0f694e7994b'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.168649 [ 3528 ] {c6623b3c-7b33-4e8d-ae6b-2c01409e9641} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:856dc7cc-d5dd-467d-9b48-99e3ed823b89'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52116) (comment: 02681_group_array_too_large_size.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qy5y2e5f ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.169607 [ 3528 ] {c6623b3c-7b33-4e8d-ae6b-2c01409e9641} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:856dc7cc-d5dd-467d-9b48-99e3ed823b89'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.214436 [ 4083 ] {edcc1f5c-384a-4e1e-9213-35bf9529b961} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:d296efef-4c45-4eff-a6b8-cba64528dcdc'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52128) (comment: 02896_illegal_sampling.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0evcej8l ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.215596 [ 4083 ] {edcc1f5c-384a-4e1e-9213-35bf9529b961} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:d296efef-4c45-4eff-a6b8-cba64528dcdc'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.224447 [ 4083 ] {015dbdd3-765a-42ac-af8b-997342c34e64} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:8dd61451-6227-47c8-a3d7-be7bfb97f635'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52142) (comment: 02475_analysis_of_variance.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6vt610e5 ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.225371 [ 4083 ] {015dbdd3-765a-42ac-af8b-997342c34e64} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:8dd61451-6227-47c8-a3d7-be7bfb97f635'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.261855 [ 4083 ] {1446f068-685e-40b7-bc09-d6010621363d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:7cabcac6-8c35-468b-b41b-6252e58d6b89'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52148) (comment: 00825_protobuf_format_splitted_nested.sh) (in query: CREATE DATABASE IF NOT EXISTS test_16tc6zp3 ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.263264 [ 4083 ] {1446f068-685e-40b7-bc09-d6010621363d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:7cabcac6-8c35-468b-b41b-6252e58d6b89'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.274508 [ 4083 ] {86211c47-70d8-412a-b870-43a7ab522363} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:4018496c-0fb8-4a08-bca6-15a1cc48944c'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52158) (comment: 01621_clickhouse_compressor.sh) (in query: CREATE DATABASE IF NOT EXISTS test_leji0kbc ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.275650 [ 4083 ] {86211c47-70d8-412a-b870-43a7ab522363} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:4018496c-0fb8-4a08-bca6-15a1cc48944c'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.287874 [ 4083 ] {071b0bad-a472-4f29-9714-88c6b4fd3aca} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:24e15114-7f94-46c9-b3f2-d3b8cf359a98'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52164) (comment: 03095_merge_and_buffer_tables.sql) (in query: CREATE DATABASE IF NOT EXISTS test_e6p6t08y ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.289093 [ 4083 ] {071b0bad-a472-4f29-9714-88c6b4fd3aca} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:24e15114-7f94-46c9-b3f2-d3b8cf359a98'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.303096 [ 4083 ] {89380292-2b77-485c-b8c1-9682b4f973be} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:26f125b6-741c-4b77-94d6-f1cd6fe553f4'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52166) (comment: 01543_avro_deserialization_with_lc.sh) (in query: CREATE DATABASE IF NOT EXISTS test_s7g5lag4 ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.304056 [ 4083 ] {89380292-2b77-485c-b8c1-9682b4f973be} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:26f125b6-741c-4b77-94d6-f1cd6fe553f4'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.315600 [ 4083 ] {95900472-5fe3-42ca-a101-5cb8d9f7b5de} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:043f8d61-28a0-4a55-9d4f-185e271bf949'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52172) (comment: 02956_format_constexpr.sql) (in query: CREATE DATABASE IF NOT EXISTS test_e2xar4zw ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.316648 [ 4083 ] {95900472-5fe3-42ca-a101-5cb8d9f7b5de} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:043f8d61-28a0-4a55-9d4f-185e271bf949'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.329085 [ 3528 ] {b59aa4a6-8fd9-4ee8-a815-9c4be7a3aa18} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:8e296cf6-cbd5-4643-aa5f-6b274ae3f546'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52188) (comment: 02122_parallel_formatting_JSONStrings.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ubqy40xr ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.330210 [ 3528 ] {b59aa4a6-8fd9-4ee8-a815-9c4be7a3aa18} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:8e296cf6-cbd5-4643-aa5f-6b274ae3f546'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.348486 [ 3966 ] {25583cf7-ce86-4d6c-a65d-3794acc3abb5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:77e19765-5342-4838-932a-59f98e819688'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52198) (comment: 03033_hive_text_read_variable_fields.sh) (in query: CREATE DATABASE IF NOT EXISTS test_w8ql4xsz ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.349520 [ 3966 ] {25583cf7-ce86-4d6c-a65d-3794acc3abb5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:77e19765-5342-4838-932a-59f98e819688'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.361542 [ 3966 ] {d815b294-09fd-4b49-b29b-64174764020b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:9b7d97ea-63bb-44fc-b13a-ae310de881c9'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52208) (comment: 01483_merge_table_join_and_group_by.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7rt0lmoc ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.363169 [ 3966 ] {d815b294-09fd-4b49-b29b-64174764020b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:9b7d97ea-63bb-44fc-b13a-ae310de881c9'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.381600 [ 3966 ] {f860c895-0fd0-4104-bb8b-4d8511cb47b4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:5fe3462c-ea0b-499d-914d-ba33899a12eb'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52214) (comment: 00553_buff_exists_materlized_column.sql) (in query: CREATE DATABASE IF NOT EXISTS test_sfwcf5bv ENGINE=Replicated('/test/db/test_2', '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:36.383582 [ 3966 ] {f860c895-0fd0-4104-bb8b-4d8511cb47b4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '48ed86120eb0:9000:048aeacb-df76-42e3-9c63-48188b170feb', current host ID: '48ed86120eb0:9000:5fe3462c-ea0b-499d-914d-ba33899a12eb'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000001710f5fc 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000170e0f68 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000170e5f0a 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c5e595 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3128e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:36.560970 [ 2979 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:37.401197 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {65f5e34d-ebac-471f-9b4d-7e1ce16ee071::202506_1_41_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:37.562378 [ 2944 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:38.563341 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:39.484329 [ 4203 ] {f896f007-7689-45d6-b1ac-b42093a5e2b3} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44386) (comment: 03143_asof_join_ddb_long.sql) (in query: SELECT SUM(value), COUNT(*) FROM skewed_probe ASOF JOIN build USING (key, begin) ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Planner/PlannerJoins.cpp:917: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e11f30 5. ./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&) @ 0x0000000017df0110 6. ./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&) @ 0x0000000017de0b12 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:39.485595 [ 4203 ] {f896f007-7689-45d6-b1ac-b42093a5e2b3} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Planner/PlannerJoins.cpp:917: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e11f30 5. ./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&) @ 0x0000000017df0110 6. ./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&) @ 0x0000000017de0b12 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:39.564113 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:40.564865 [ 2827 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:40.982770 [ 3528 ] {eab782ea-e783-43ed-bd38-d9b5715877db} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58122) (comment: 01883_with_grouping_sets.sql) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets ((fact_1_id), (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5281: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493dd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:40.983509 [ 3528 ] {eab782ea-e783-43ed-bd38-d9b5715877db} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5281: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493dd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:41.044743 [ 3528 ] {17b201de-239f-40e3-b88a-21e368e65074} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58122) (comment: 01883_with_grouping_sets.sql) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets (fact_1_id, (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5281: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493dd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:41.045408 [ 3528 ] {17b201de-239f-40e3-b88a-21e368e65074} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5281: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493dd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:41.565726 [ 2788 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:42.304384 [ 4083 ] {0d6cb522-e64d-47fa-ace2-da7604f2678e} executeQuery: Code: 36. DB::Exception: Cannot DROP or CLEAR all columns. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58154) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/AlterCommands.cpp:1649: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190e3a73 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2072b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.305131 [ 4083 ] {0d6cb522-e64d-47fa-ace2-da7604f2678e} TCPHandler: Code: 36. DB::Exception: Cannot DROP or CLEAR all columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/AlterCommands.cpp:1649: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190e3a73 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2072b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.311459 [ 2764 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001769e9e7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000001769f17c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176aa3a2 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:42.482666 [ 4083 ] {712ac59b-6aa8-4882-8496-ba00d11a0262} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58154) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008886946 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e4b4d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc442 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.483327 [ 4083 ] {712ac59b-6aa8-4882-8496-ba00d11a0262} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008886946 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e4b4d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc442 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.490204 [ 4083 ] {57c9452d-8ca5-4d43-80ee-37b468d81215} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58154) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION 'asdasd';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008886946 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e4b4d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc442 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.490867 [ 4083 ] {57c9452d-8ca5-4d43-80ee-37b468d81215} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008886946 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e4b4d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc442 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.512969 [ 4083 ] {cef18834-8186-4299-8f7a-6e95c61f9a25} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58154) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008886946 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e4b4d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc442 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.513435 [ 4083 ] {cef18834-8186-4299-8f7a-6e95c61f9a25} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008886946 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e4b4d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199dc442 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.566492 [ 2768 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:42.624221 [ 4083 ] {6dc53443-e95f-47c9-a309-f867322a20aa} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58154) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000019a599ec 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199deaaa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.624982 [ 4083 ] {6dc53443-e95f-47c9-a309-f867322a20aa} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000019a599ec 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199deaaa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.641196 [ 4083 ] {4d5f55fa-13e5-4e95-8286-6170a20bbbdd} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58154) (comment: 01388_clear_all_columns.sql) (in query: -- y is only real column in table ALTER TABLE test CLEAR 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000019a599ec 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199deaaa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:42.641600 [ 4083 ] {4d5f55fa-13e5-4e95-8286-6170a20bbbdd} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000019a599ec 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199deaaa 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:43.567552 [ 2714 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:43.793130 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:44.568428 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:44.909263 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_91_18}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:45.090075 [ 3528 ] {243846ba-b5f9-4ed7-93ee-7aec2beaae8e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36838) (comment: 02406_minmax_behaviour.sql) (in query: WITH arrayJoin([1, 2, 3, nan, 4, 5]) AS data, arrayJoin([nan, 1, 2, 3, 4]) AS data2, arrayJoin([1, 2, 3, 4, nan]) AS data3, arrayJoin([nan, nan, nan]) AS data4, arrayJoin([nan, 1, 2, 3, nan]) AS data5 SELECT max(data), max(data2), max(data3), max(data4), max(data5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:45.091370 [ 3528 ] {243846ba-b5f9-4ed7-93ee-7aec2beaae8e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:45.569593 [ 3142 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:45.962046 [ 3528 ] {5499e4a8-6aca-427b-8962-28337fb490dd} executeQuery: Code: 43. DB::Exception: Elements of array of second argument of function roundDown must be numeric type.: In scope SELECT 1 AS x, roundDown(x, []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36862) (comment: 00805_round_down.sql) (in query: SELECT 1 as x, roundDown(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::FunctionRoundDown::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000008644cf6 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:45.963005 [ 3528 ] {5499e4a8-6aca-427b-8962-28337fb490dd} TCPHandler: Code: 43. DB::Exception: Elements of array of second argument of function roundDown must be numeric type.: In scope SELECT 1 AS x, roundDown(x, []). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::FunctionRoundDown::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000008644cf6 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:01:46.105481 [ 3528 ] {42f4d1f3-c77f-45e7-857a-2eeead61f9e9} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36862) (comment: 00805_round_down.sql) (in query: SELECT 1 as x, roundDown(x, emptyArrayUInt8());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008710a94 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:46.106258 [ 3528 ] {42f4d1f3-c77f-45e7-857a-2eeead61f9e9} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008710a94 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:46.201413 [ 3528 ] {bb2ee63c-e1e7-41d4-8926-0a9b68652b25} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36862) (comment: 00805_round_down.sql) (in query: SELECT roundDown(number, [number]) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008710a94 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:46.202216 [ 3528 ] {bb2ee63c-e1e7-41d4-8926-0a9b68652b25} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008710a94 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:46.570761 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:47.571831 [ 3081 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:48.572600 [ 2689 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:49.573348 [ 3003 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:49.879695 [ 3528 ] {52fb59f3-d9be-461d-b2c9-f9f8f58c5fee} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_aliases' in scope alias2 AS (SELECT number FROM test_aliases). (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36964) (comment: 02834_analyzer_with_statement_references.sql) (in query: WITH test_aliases AS (SELECT number FROM numbers(20)), alias2 AS (SELECT number FROM test_aliases) SELECT number FROM alias2 SETTINGS enable_global_with_statement = 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499a1d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce56b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:49.880701 [ 3528 ] {52fb59f3-d9be-461d-b2c9-f9f8f58c5fee} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_aliases' in scope alias2 AS (SELECT number FROM test_aliases). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499a1d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce56b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:50.574065 [ 2973 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:51.574910 [ 2948 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:52.496879 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_1_73_25}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:52.576022 [ 2914 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:52.613218 [ 4083 ] {65586e6c-3075-4e9b-96b8-439b871dfb7c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37018) (comment: 02892_orc_filter_pushdown.sql) (in query: -- Go over all types individually -- { echoOn } select count(), sum(number) from file('02892.orc') where indexHint(i8 in (10, 15, -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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:52.615018 [ 4083 ] {65586e6c-3075-4e9b-96b8-439b871dfb7c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:53.577096 [ 2880 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:54.484272 [ 4083 ] {f0226ce7-62a5-4f6d-b77a-029c334c29b5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52342) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016490716 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016490385 9. ./contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x000000001657717a 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001655d45c 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::preFinalize() @ 0x000000001655c9c4 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 13. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000019c84696 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000019c81822 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd14a0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019de9743 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 20. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 27. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 28. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:01:54.485187 [ 4083 ] {f0226ce7-62a5-4f6d-b77a-029c334c29b5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016490716 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016490385 9. ./contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x000000001657717a 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001655d45c 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::preFinalize() @ 0x000000001655c9c4 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 13. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000019c84696 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000019c81822 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd14a0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019de9743 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 20. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 27. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 28. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:01:54.578016 [ 2856 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:55.579397 [ 2821 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:55.632535 [ 4083 ] {45e21c6a-2e59-44d3-9a7e-1a2a36d02810} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=757). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52396) (comment: 02366_kql_datatype.sql) (in query: print real(0.01);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:55.632852 [ 4083 ] {45e21c6a-2e59-44d3-9a7e-1a2a36d02810} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:56.134361 [ 3866 ] {adb67c3d-70f3-40a9-8c82-2684b14a433a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=757). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52408) (comment: 02232_functions_to_subcolumns_alias.sql) (in query: SELECT tupleElement(t, 1) as t0, t0 FROM t_functions_to_subcolumns_alias FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:56.135195 [ 3866 ] {adb67c3d-70f3-40a9-8c82-2684b14a433a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:56.580316 [ 2785 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:57.225789 [ 3866 ] {9ed17ebf-5f46-4912-aecd-6f54dad1b111} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern '\': In scope SELECT '\\' LIKE '\\'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52434) (comment: 01847_bad_like.sql) (in query: SELECT '\\' LIKE '\\';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x000000000fa8b46a 5. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000000c090435 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000000c08f716 7. DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000000c08c460 8. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c08b257 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 2025.06.12 19:01:57.226557 [ 3866 ] {9ed17ebf-5f46-4912-aecd-6f54dad1b111} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern '\': In scope SELECT '\\' LIKE '\\'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x000000000fa8b46a 5. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000000c090435 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000000c08f716 7. DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000000c08c460 8. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c08b257 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 2025.06.12 19:01:57.580996 [ 2760 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:58.581725 [ 2727 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:01:59.169128 [ 4203 ] {2e6c6f80-fbbc-4321-bb90-1519f27144ca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=754). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52500) (comment: 02096_date_time_1970_saturation2.sql) (in query: select toStartOfMonth(toDateTime(0, 'Africa/Monrovia'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:59.178378 [ 4203 ] {2e6c6f80-fbbc-4321-bb90-1519f27144ca} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:01:59.582415 [ 2701 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:00.641559 [ 3194 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:00.883671 [ 4203 ] {0753b8c1-2834-4498-9c95-7628b483534a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52528) (comment: 03040_dynamic_type_alters_2_wide_merge_tree.sql) (in query: select x, y, d1, d1.String, d1.UInt64, d1.Date, d1.`Tuple(a UInt64)`.a 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001702104f 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:02:00.885554 [ 4203 ] {0753b8c1-2834-4498-9c95-7628b483534a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001702104f 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:02:01.035812 [ 3966 ] {352d6cd7-febd-43e3-85b7-942f4064e1a8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46182) (comment: 03040_dynamic_type_alters_2_wide_merge_tree.sql) (in query: DROP DATABASE IF EXISTS test_eub2yuog ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:01.036751 [ 3966 ] {352d6cd7-febd-43e3-85b7-942f4064e1a8} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:01.187007 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:01.544555 [ 3528 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:01.642378 [ 3119 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:02.134809 [ 5737 ] {0828349c-6848-4eee-9962-98e284db1a25} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52576) (comment: 03205_parallel_window_finctions_and_column_sparse_bug.sql) (in query: SELECT d, c, row_number() over (partition by d order by c) as c8 FROM t qualify c8=1 order by d settings max_threads=2, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/SerializationWrapper.cpp:13: DB::SerializationWrapper::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001705ff4a 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 2025.06.12 19:02:02.136739 [ 5737 ] {0828349c-6848-4eee-9962-98e284db1a25} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/SerializationWrapper.cpp:13: DB::SerializationWrapper::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001705ff4a 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 2025.06.12 19:02:02.224106 [ 3866 ] {bc7c3b9e-4df2-4d43-abe2-b7e145697f39} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56174) (comment: 03205_parallel_window_finctions_and_column_sparse_bug.sql) (in query: DROP DATABASE IF EXISTS test_g842bdrw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:02.224856 [ 3866 ] {bc7c3b9e-4df2-4d43-abe2-b7e145697f39} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:02.230513 [ 5737 ] {85249a35-1f43-4652-a4db-04cfaf41e50c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56180) (comment: 03205_parallel_window_finctions_and_column_sparse_bug.sql) (in query: DROP DATABASE IF EXISTS test_g842bdrw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:02.231916 [ 5737 ] {85249a35-1f43-4652-a4db-04cfaf41e50c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:02.374419 [ 5737 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:02.643172 [ 3086 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:02.861483 [ 6444 ] {} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:02:30: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:03.279394 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:03.643913 [ 3052 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:04.148523 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:04.644593 [ 3014 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:04.997443 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:05.148937 [ 3866 ] {41b8529b-1937-47e7-b091-923dcacc45aa} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 46 ('numbers'): numbers. Expected one of: token, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59406) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 'find_me_[hidden]' FRRRROM numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000007648aa3 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) @ 0x000000001b0167f0 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b0168af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182130ab 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&)>) @ 0x000000001821af79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:05.149944 [ 3866 ] {41b8529b-1937-47e7-b091-923dcacc45aa} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 46 ('numbers'): numbers. Expected one of: token, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000007648aa3 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) @ 0x000000001b0167f0 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b0168af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182130ab 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&)>) @ 0x000000001821af79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:05.645333 [ 2990 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:05.814185 [ 3849 ] {cf4600f9-81fe-460c-8c58-d69d934bc9fd} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'credit_card_number' in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59892) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 1 FROM system.numbers WHERE credit_card_number='find_me_[hidden]' FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174d629c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749bddf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5108 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017491889 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:05.815834 [ 3849 ] {cf4600f9-81fe-460c-8c58-d69d934bc9fd} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'credit_card_number' in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174d629c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749bddf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5108 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017491889 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:05.873527 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:06.001167 [ 3866 ] {d4e052f7-0491-46bd-9562-f210ed5768b4} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'credit_card_number' in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59408) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 1 FROM system.numbers WHERE credit_card_number='find_me_[hidden]' FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174d629c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749bddf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5108 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017491889 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 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&)>) @ 0x000000001821af79 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:06.002108 [ 3866 ] {d4e052f7-0491-46bd-9562-f210ed5768b4} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'credit_card_number' in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174d629c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749bddf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5108 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017491889 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 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&)>) @ 0x000000001821af79 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:06.646106 [ 2881 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:06.731607 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:06.877609 [ 3849 ] {d423faad-c866-4d46-850c-c5861ecd632c} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(100_UInt8 :: 1, minus(__table1.number, 10_UInt8) :: 0) -> intDiv(100_UInt8, minus(__table1.number, 10_UInt8)) Int8 : 2'. (ILLEGAL_DIVISION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59912) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 'find_me_[hidden]', intDiv( 100, number - 10) FROM numbers(11) FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000a00a5b5 5. void DB::impl_::BinaryOperation, _BitInt(8)>::process<(DB::impl_::OpCase)1>(char8_t const*, long const*, DB::impl_::BinaryOperation, _BitInt(8)>*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b09211e 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b2999ae 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000b2931d0 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000b29184b 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b28cd20 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b28afe6 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b2897f6 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:06.878885 [ 3849 ] {d423faad-c866-4d46-850c-c5861ecd632c} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(100_UInt8 :: 1, minus(__table1.number, 10_UInt8) :: 0) -> intDiv(100_UInt8, minus(__table1.number, 10_UInt8)) Int8 : 2'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000a00a5b5 5. void DB::impl_::BinaryOperation, _BitInt(8)>::process<(DB::impl_::OpCase)1>(char8_t const*, long const*, DB::impl_::BinaryOperation, _BitInt(8)>*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b09211e 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b2999ae 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000b2931d0 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000b29184b 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b28cd20 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b28afe6 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b2897f6 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:07.245901 [ 4083 ] {56318d04-295b-492d-bf29-e76f4d9cf411} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59940) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016490716 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016490385 9. ./contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x000000001657717a 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001655d45c 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::preFinalize() @ 0x000000001655c9c4 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 13. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:46: DB::MergeTreeDataPartWriterOnDisk::Stream::preFinalize() @ 0x0000000019ac600b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:0: DB::MergeTreeDataPartWriterWide::fillDataChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000019ad14f5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:731: DB::MergeTreeDataPartWriterWide::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000019ad1c40 17. ./contrib/llvm-project/libcxx/include/__hash_table:1727: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000019c80bef 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd14a0 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019de9743 21. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 22. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 28. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 29. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 30. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 2025.06.12 19:02:07.247050 [ 4083 ] {56318d04-295b-492d-bf29-e76f4d9cf411} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016490716 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016490385 9. ./contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x000000001657717a 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001655d45c 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::preFinalize() @ 0x000000001655c9c4 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 13. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000001730958b 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:46: DB::MergeTreeDataPartWriterOnDisk::Stream::preFinalize() @ 0x0000000019ac600b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:0: DB::MergeTreeDataPartWriterWide::fillDataChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000019ad14f5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:731: DB::MergeTreeDataPartWriterWide::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000019ad1c40 17. ./contrib/llvm-project/libcxx/include/__hash_table:1727: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000019c80bef 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cd14a0 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019de9743 21. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 22. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 28. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 29. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 30. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 2025.06.12 19:02:07.625236 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:07.647025 [ 2933 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:08.282681 [ 4101 ] {cbd06ae3-fc41-49f2-9c5a-d3b5525ff05c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59954) (comment: 00956_sensitive_data_masking.sh) (in query: select sleepEachRow(1) from numbers(10) where ignore('find_me_[hidden]')=0 and ignore('fwerkh_that_magic_string_make_me_unique') = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edebb0 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e19a8 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e15e8 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:08.336065 [ 4101 ] {cbd06ae3-fc41-49f2-9c5a-d3b5525ff05c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edebb0 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e19a8 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e15e8 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:08.480595 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:08.647733 [ 2903 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:09.335134 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:09.648444 [ 2877 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:10.152357 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:10.649282 [ 2850 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:11.045984 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:11.649922 [ 2826 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:11.864172 [ 4083 ] {bc6ef345-dde5-4854-b163-58d79c0aa404} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=8): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60114) (comment: 00956_sensitive_data_masking.sh) (in query: select * from system.query_log where current_database = currentDatabase() AND event_date >= yesterday() and query like '%TOPSECRET%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016fb7c3e 13. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f5cd50 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 2025.06.12 19:02:11.873689 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:11.923171 [ 4083 ] {bc6ef345-dde5-4854-b163-58d79c0aa404} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=8): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016fb7c3e 13. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f5cd50 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 2025.06.12 19:02:12.650895 [ 2797 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:12.705267 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:12.740548 [ 3849 ] {3cf8b91c-c533-4771-8dde-5c7f9b005ba8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51066) (comment: 00956_sensitive_data_masking.sh) (in query: select * from system.query_log where current_database = currentDatabase() AND event_date >= yesterday() and exception like '%TOPSECRET%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:0: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016fb7b6d 14. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f5cd50 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 18. ./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&) @ 0x0000000019ab0a94 19. ./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 @ 0x0000000019aabed2 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 2025.06.12 19:02:12.747690 [ 3849 ] {3cf8b91c-c533-4771-8dde-5c7f9b005ba8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:0: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016fb7b6d 14. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f5cd50 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 18. ./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&) @ 0x0000000019ab0a94 19. ./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 @ 0x0000000019aabed2 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 2025.06.12 19:02:13.583112 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:13.651557 [ 2772 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:14.433140 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:14.652622 [ 2731 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:15.318612 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:15.653310 [ 2705 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:16.161129 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:16.654645 [ 3168 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:16.996476 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:17.655409 [ 3142 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:17.843934 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:18.303013 [ 3866 ] {4c2171e0-80e4-4744-aada-a6b2b0dd3110} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59704) (comment: 00956_sensitive_data_masking.sh) (in query: DROP DATABASE IF EXISTS test_8vh725r8 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:18.303879 [ 3866 ] {4c2171e0-80e4-4744-aada-a6b2b0dd3110} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:18.329409 [ 4203 ] {e7240ecb-3ece-4c8b-b53e-919adb8ef4b6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59716) (comment: 00956_sensitive_data_masking.sh) (in query: DROP DATABASE IF EXISTS test_8vh725r8 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:18.332921 [ 4203 ] {e7240ecb-3ece-4c8b-b53e-919adb8ef4b6} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:18.656152 [ 3106 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:18.699293 [ 3826 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:19.560011 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:19.656802 [ 3075 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:20.449642 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:20.657443 [ 3038 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:20.950884 [ 3966 ] {41c26bff-cb05-4cde-9cf6-1647b684866c} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51280) (comment: 01710_projections.sql) (in query: select * from projection_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1f01 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:20.951425 [ 3966 ] {41c26bff-cb05-4cde-9cf6-1647b684866c} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1f01 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:21.040433 [ 3966 ] {0ed05ac9-5773-4c13-8b88-7aa287372318} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51280) (comment: 01710_projections.sql) (in query: select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) from projection_test join (select 1) x on 1 where domain = '1' group by dt_m order by dt_m;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1f01 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:21.041109 [ 3966 ] {0ed05ac9-5773-4c13-8b88-7aa287372318} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1f01 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:21.350100 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:21.653839 [ 3966 ] {a1814f8a-5954-4736-9253-517e790cf7b7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, jobs=766). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51280) (comment: 01710_projections.sql) (in query: SELECT 2, -1 FROM projection_test PREWHERE domain_alias = 1. WHERE domain = NULL GROUP BY -9223372036854775808 ORDER BY countIf(first_time = 0) / count(-2147483649) DESC NULLS LAST, 1048576 DESC 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:21.654923 [ 3966 ] {a1814f8a-5954-4736-9253-517e790cf7b7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=796, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:21.658056 [ 2964 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:21.725351 [ 4203 ] {e567290f-98e9-4256-aa8a-96fd17bb36ac} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59730) (comment: 01710_projections.sql) (in query: DROP DATABASE IF EXISTS test_osd17kwh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:21.726008 [ 4203 ] {e567290f-98e9-4256-aa8a-96fd17bb36ac} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:21.762792 [ 4101 ] {07a46883-77ba-44ea-8d2e-6b9fa0fadd3e} 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.10057.altinitytest (altinity build)) (from [::1]:51376) (comment: 00732_quorum_insert_have_data_before_quorum_zookeeper_long.sql) (in query: SELECT x FROM quorum2 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:21.763349 [ 4101 ] {07a46883-77ba-44ea-8d2e-6b9fa0fadd3e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:22.325677 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:22.491622 [ 3849 ] {8cf57531-8379-4960-aa08-e4ea8aed37d5} executeQuery: Code: 57. DB::Exception: Table test_9.ts already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44770) (comment: 02730_with_fill_by_sorting_prefix.sql) (in query: CREATE TABLE ts (`sensor_id` UInt64, `timestamp` UInt64, `value` Float64) ENGINE = MergeTree ORDER BY (sensor_id, timestamp) SETTINGS index_granularity = 54801, min_bytes_for_wide_part = 888533283, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 15, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 143481153, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 8821350, merge_max_block_size = 12798, old_parts_lifetime = 29., 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 = 4963499412, index_granularity_bytes = 17839996, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 94577, primary_key_compress_block_size = 69777), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:22.492470 [ 3849 ] {8cf57531-8379-4960-aa08-e4ea8aed37d5} TCPHandler: Code: 57. DB::Exception: Table test_9.ts already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:22.659308 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:23.122006 [ 3966 ] {6139fc42-2cd7-4bae-80bd-e1ad8568efe1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51062) (comment: 00098_1_union_all.sql) (in query: DROP DATABASE IF EXISTS test_3goa6wn8 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:23.122863 [ 3966 ] {6139fc42-2cd7-4bae-80bd-e1ad8568efe1} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:23.167704 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:23.660109 [ 3006 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:24.079146 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:24.660967 [ 2868 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:24.923506 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:25.661666 [ 2854 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:25.794236 [ 3966 ] {e6e387e0-6ec0-4d76-81b5-f646646f2696} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44868) (comment: 01545_system_errors.sh) (in query: SELECT throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3da96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:25.795256 [ 3966 ] {e6e387e0-6ec0-4d76-81b5-f646646f2696} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3da96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:25.801057 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:26.631554 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:26.662766 [ 2812 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:27.451670 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:27.452764 [ 3849 ] {21f0b93b-0502-4990-8443-de6fcc89fb88} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(not(__table1.dummy) :: 2) -> throwIf(not(__table1.dummy)) UInt8 : 0'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37580) (comment: 01545_system_errors.sh) (in query: SELECT `__table1`.`dummy` AS `dummy` FROM `system`.`one` AS `__table1` WHERE throwIf(NOT `__table1`.`dummy`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3da96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001a699df0 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001a699c57 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:27.453875 [ 3849 ] {21f0b93b-0502-4990-8443-de6fcc89fb88} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(not(__table1.dummy) :: 2) -> throwIf(not(__table1.dummy)) UInt8 : 0'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3da96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001a699df0 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001a699c57 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:27.457516 [ 3966 ] {82953826-5938-44c1-b306-472ba3c3bcc7} executeQuery: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(not(__table1.dummy) :: 2) -> throwIf(not(__table1.dummy)) UInt8 : 0'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3da96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001a699df0 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001a699c57 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44910) (comment: 01545_system_errors.sh) (in query: SELECT * FROM remote('127.2', system.one) where throwIf(not dummy)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:02:27.458855 [ 3966 ] {82953826-5938-44c1-b306-472ba3c3bcc7} TCPHandler: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(not(__table1.dummy) :: 2) -> throwIf(not(__table1.dummy)) UInt8 : 0'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3da96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001a699df0 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001a699c57 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:02:27.663622 [ 2787 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:28.295857 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:28.664324 [ 2963 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:29.181276 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:29.665152 [ 2743 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:29.720524 [ 3966 ] {43864768-3af7-4a1e-95ab-0f9fccf8a53c} executeQuery: Code: 390. DB::Exception: Table `mv` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44952) (comment: 02380_insert_mv_race.sh) (in query: ATTACH TABLE mv), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000001709a105 5. ./src/Databases/IDatabase.h:396: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c418b4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:29.721640 [ 3966 ] {43864768-3af7-4a1e-95ab-0f9fccf8a53c} TCPHandler: Code: 390. DB::Exception: Table `mv` 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000001709a105 5. ./src/Databases/IDatabase.h:396: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c418b4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:30.022147 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:30.665894 [ 2709 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:30.875172 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:31.667078 [ 3175 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:31.773810 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:32.633657 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:32.667989 [ 3149 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:32.983198 [ 8296 ] {} ExternalDictionariesLoader: Could not load external dictionary '8f9565a7-ca79-44b7-b1db-e6e64390336b', next update is scheduled at 2025-06-12 19:06:51: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 14. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff50ef1 15. DB::FlatDictionary::loadData() @ 0x000000000ff5644b 16. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff55bc0 17. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000ff7b7d7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000162188db 19. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000017bcc5a0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017bdd5e0 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017bd9131 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017be17a8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017be15a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:33.482612 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:33.668648 [ 3189 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:34.394273 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:34.669381 [ 3112 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:34.943320 [ 3966 ] {dc89376f-fb29-4f0e-a03e-e5b8ae14919b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=142, jobs=65). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44982) (comment: 02380_insert_mv_race.sh) (in query: INSERT INTO null SELECT * FROM numbers_mt(1000) settings max_threads=1000, max_insert_threads=1000, max_block_size=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:35.269106 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:35.670349 [ 3079 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:35.692205 [ 3966 ] {dc89376f-fb29-4f0e-a03e-e5b8ae14919b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=142, jobs=65). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:36.071278 [ 5779 ] {390ccebb-54aa-4aff-9faf-67de1cb36647} executeQuery: Code: 60. DB::Exception: Table test_guu5sgg0.`.inner_id.98a47ccb-a0d9-4e81-b7c8-3b827ea02ac2` (aa06f112-5a12-4665-a429-a17d9a53860b) does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60384) (comment: 02380_insert_mv_race.sh) (in query: DROP DATABASE IF EXISTS test_guu5sgg0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./contrib/llvm-project/libcxx/include/optional:897: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768ed6f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:606: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000192ab74a 7. ./src/Storages/StorageMaterializedView.h:36: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000192b4b7f 8. ./build_docker/./src/Interpreters/IInterpreter.cpp:39: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d831 9. ./src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a967 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6e9aa 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:36.072571 [ 5779 ] {390ccebb-54aa-4aff-9faf-67de1cb36647} DynamicQueryHandler: Code: 60. DB::Exception: Table test_guu5sgg0.`.inner_id.98a47ccb-a0d9-4e81-b7c8-3b827ea02ac2` (aa06f112-5a12-4665-a429-a17d9a53860b) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./contrib/llvm-project/libcxx/include/optional:897: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768ed6f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:606: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000192ab74a 7. ./src/Storages/StorageMaterializedView.h:36: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000192b4b7f 8. ./build_docker/./src/Interpreters/IInterpreter.cpp:39: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d831 9. ./src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a967 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6e9aa 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:36.093401 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:36.671364 [ 3057 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:36.913778 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:37.672046 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:37.748088 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:38.573431 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:38.672713 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:38.704583 [ 3849 ] {ddef9317-0a13-4464-b0e3-ab8f404b52c9} executeQuery: Code: 117. DB::Exception: Incorrect data: Sign = -117 (must be 1 or -1). (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57342) (comment: 01679_incorrect_data_on_insert_collapsing.sh) (in query: INSERT INTO collapsing_merge_tree 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x000000001a7e4c95 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:426: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000019ccc33e 6. ./contrib/llvm-project/libcxx/include/vector:1348: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cce63f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:38.706167 [ 3849 ] {ddef9317-0a13-4464-b0e3-ab8f404b52c9} TCPHandler: Code: 117. DB::Exception: Incorrect data: Sign = -117 (must be 1 or -1). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x000000001a7e4c95 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:426: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000019ccc33e 6. ./contrib/llvm-project/libcxx/include/vector:1348: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cce63f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:39.433972 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:39.673351 [ 2962 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:39.849606 [ 4083 ] {2c38ecfd-b2d6-464f-bb21-9268c0c9517c} executeQuery: Code: 57. DB::Exception: Table test_ebfo8buy.t_ttl_modify_column already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57392) (comment: 01923_ttl_with_modify_column.sql) (in query: CREATE TABLE t_ttl_modify_column (`InsertionDateTime` DateTime) ENGINE = MergeTree ORDER BY tuple() TTL InsertionDateTime + toIntervalDay(3) SETTINGS min_bytes_for_wide_part = 0, index_granularity = 6660, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 23, min_bytes_for_full_part_storage = 365808837, compact_parts_max_bytes_to_buffer = 252057997, compact_parts_max_granules_to_buffer = 192, compact_parts_merge_max_bytes_to_prefetch_part = 26155757, merge_max_block_size = 2847, old_parts_lifetime = 71., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 296058, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4613714, concurrent_part_removal_threshold = 96, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 34652, primary_key_compress_block_size = 86866), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:39.850146 [ 4083 ] {2c38ecfd-b2d6-464f-bb21-9268c0c9517c} TCPHandler: Code: 57. DB::Exception: Table test_ebfo8buy.t_ttl_modify_column already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:39.928977 [ 5779 ] {0a1eb3e2-8500-4e7f-948f-bf4b832b96e6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60412) (comment: 01923_ttl_with_modify_column.sql) (in query: DROP DATABASE IF EXISTS test_ebfo8buy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:39.929805 [ 5779 ] {0a1eb3e2-8500-4e7f-948f-bf4b832b96e6} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:39.937701 [ 3849 ] {08802343-d706-4660-88d9-e65af546662c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60418) (comment: 01923_ttl_with_modify_column.sql) (in query: DROP DATABASE IF EXISTS test_ebfo8buy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:39.939570 [ 3849 ] {08802343-d706-4660-88d9-e65af546662c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:40.274877 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:40.674072 [ 2941 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:41.090966 [ 3866 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:41.675074 [ 2916 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:41.912333 [ 3866 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.675803 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:42.824201 [ 4083 ] {23b8c6c8-44ce-4164-bea7-576e0138f8ee} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48154) (comment: 01355_ilike.sql) (in query: DROP DATABASE IF EXISTS test_tv79fw99 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.825221 [ 4083 ] {23b8c6c8-44ce-4164-bea7-576e0138f8ee} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:42.825930 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.837435 [ 3866 ] {57427093-1781-4aff-bd48-9694c16e421e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48160) (comment: 01355_ilike.sql) (in query: DROP DATABASE IF EXISTS test_tv79fw99 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.838333 [ 3866 ] {57427093-1781-4aff-bd48-9694c16e421e} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:42.845353 [ 3849 ] {4eb02bce-df13-4523-9f04-5980e11b0a0b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48162) (comment: 01355_ilike.sql) (in query: DROP DATABASE IF EXISTS test_tv79fw99 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.846426 [ 3849 ] {4eb02bce-df13-4523-9f04-5980e11b0a0b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:42.892152 [ 4083 ] {033fb3f4-16d4-4d77-91f1-cac354b6362b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48172) (comment: 01355_ilike.sql) (in query: DROP DATABASE IF EXISTS test_tv79fw99 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.893644 [ 4083 ] {033fb3f4-16d4-4d77-91f1-cac354b6362b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:42.901198 [ 3849 ] {b2d498b4-58b9-4b8e-8bb5-5c4cb8ce1521} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48182) (comment: 01355_ilike.sql) (in query: DROP DATABASE IF EXISTS test_tv79fw99 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.901954 [ 3849 ] {b2d498b4-58b9-4b8e-8bb5-5c4cb8ce1521} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:42.908500 [ 4083 ] {3c42a947-42f6-4b2f-81ac-ad232c924261} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48194) (comment: 01355_ilike.sql) (in query: DROP DATABASE IF EXISTS test_tv79fw99 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.909196 [ 4083 ] {3c42a947-42f6-4b2f-81ac-ad232c924261} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:42.915131 [ 3849 ] {12aee4ba-3e51-4672-9b7d-bd1b45e24ea1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48206) (comment: 01355_ilike.sql) (in query: DROP DATABASE IF EXISTS test_tv79fw99 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:42.915792 [ 3849 ] {12aee4ba-3e51-4672-9b7d-bd1b45e24ea1} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:43.676806 [ 2981 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:43.699972 [ 3866 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:43.762311 [ 3849 ] {914a4059-d433-4353-9e1c-f45708b003b0} executeQuery: Code: 520. DB::Exception: Cannot drop/detach dictionary db_01048.t_01048 as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33276) (comment: 01048_exists_query.sql) (in query: -- But dictionary-tables cannot be dropped as usual tables. DROP TABLE db_01048.t_01048;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x000000001917b664 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6be50 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:43.763101 [ 3849 ] {914a4059-d433-4353-9e1c-f45708b003b0} TCPHandler: Code: 520. DB::Exception: Cannot drop/detach dictionary db_01048.t_01048 as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x000000001917b664 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6be50 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:43.768329 [ 3849 ] {4ef1d6ae-9c7d-4898-a8af-e265baa0a3b8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33276) (comment: 01048_exists_query.sql) (in query: DROP DICTIONARY db_01048.t_01048;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:43.768739 [ 3849 ] {4ef1d6ae-9c7d-4898-a8af-e265baa0a3b8} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:44.588277 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:44.677632 [ 2856 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:45.427987 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:45.678319 [ 2829 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:46.325733 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:46.679180 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:46.956741 [ 4083 ] {228fc9cc-3ffd-4051-a5a0-66dbe34e93dc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48262) (comment: 02225_parallel_distributed_insert_select_view.sh) (in query: DROP DATABASE IF EXISTS test_a6vcv9cr ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:46.957575 [ 4083 ] {228fc9cc-3ffd-4051-a5a0-66dbe34e93dc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:46.970747 [ 4101 ] {48a94063-664b-4c47-8570-2a740110129c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48266) (comment: 02225_parallel_distributed_insert_select_view.sh) (in query: DROP DATABASE IF EXISTS test_a6vcv9cr ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:46.971742 [ 4101 ] {48a94063-664b-4c47-8570-2a740110129c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:47.155121 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:47.680046 [ 2783 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:48.043795 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:48.680823 [ 2763 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:48.872394 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:49.681456 [ 2745 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:49.761579 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:50.682134 [ 2728 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:50.697266 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:51.594939 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:51.683380 [ 2811 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:52.535910 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:52.684264 [ 3178 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:53.428123 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:53.685163 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:54.383247 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:54.685898 [ 3127 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:55.377913 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:55.686636 [ 3110 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:56.299494 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:56.687775 [ 3097 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:57.201220 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:57.688615 [ 3083 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:58.088922 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:58.689707 [ 3052 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:58.986281 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:02:59.690543 [ 2864 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:02:59.825629 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:00.647188 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:00.691309 [ 3024 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:01.559126 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:01.692077 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:02.382019 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:02.692699 [ 2952 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:03.228293 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:03.693387 [ 2940 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:04.076176 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:04.435052 [ 4101 ] {0ccc6e26-e540-4a7c-bc67-bb499d343528} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=766). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39394) (comment: 02967_parallel_replicas_joins_and_analyzer.gen.sql) (in query: explain description=0 with sub1 as (select x, y from tab1 where x != 2), sub2 as (select y, z from tab2 where y != 4), sub3 as (select l.x, l.y, r.y, r.z as z from sub1 l any left join sub2 r on l.y = r.y), sub4 as (select z, a from tab3 where z != 8), sub5 as (select sum(x), sum(y), sum(r.y), sum(z), sum(rr.z), sum(a), key from sub3 ll any left join sub4 rr on ll.z = rr.z group by x % 2 as key) select * from sub5 order by key SETTINGS enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, prefer_localhost_replica = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017bdc9b1 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x0000000017bd76e0 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x0000000017bef43c 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x0000000017beea89 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017bf1706 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017bf1622 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:04.435931 [ 4101 ] {0ccc6e26-e540-4a7c-bc67-bb499d343528} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017bdc9b1 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x0000000017bd76e0 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x0000000017bef43c 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x0000000017beea89 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017bf1706 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017bf1622 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:04.694044 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:04.896463 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:05.694961 [ 2887 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:05.726915 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:06.585479 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:06.695768 [ 2895 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:07.412751 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:07.696433 [ 2843 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:08.269434 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:08.697264 [ 2834 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:09.109595 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:09.698094 [ 2815 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:09.941987 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:10.698965 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:10.809949 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:11.636895 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:11.699616 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:12.122277 [ 3826 ] {fcda9141-2bbc-47d5-9bce-aac910e0b652} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/disks/s3_disk/store/050/050c1b95-4107-46ee-b3a1-e0887762702e/all_1_6_1/ in table test_15.test (050c1b95-4107-46ee-b3a1-e0887762702e) located on disk s3_disk of type s3, from mark 171 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51382) (comment: 02963_remote_read_small_buffer_size_bug.sh) (in query: OPTIMIZE TABLE test FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c0fd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001625ab4c 9. ./build_docker/./src/Disks/IO/AsynchronousBoundedReadBuffer.cpp:90: DB::AsynchronousBoundedReadBuffer::readAsync(char*, unsigned long, Priority) @ 0x00000000165218db 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousBoundedReadBuffer::prefetch(Priority) @ 0x0000000016521dcb 11. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::prefetch(Priority) @ 0x0000000016d5d6b7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bef531 13. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019bec888 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000019bec248 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019beccba 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:234: DB::MergeTreeSequentialSource::generate() @ 0x0000000019bf4ac2 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:555: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() @ 0x000000001996a4a2 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 29. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e53e16 30. ./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) @ 0x0000000019e5ab6b 31. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 2025.06.12 19:03:12.123271 [ 3826 ] {fcda9141-2bbc-47d5-9bce-aac910e0b652} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/disks/s3_disk/store/050/050c1b95-4107-46ee-b3a1-e0887762702e/all_1_6_1/ in table test_15.test (050c1b95-4107-46ee-b3a1-e0887762702e) located on disk s3_disk of type s3, from mark 171 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c0fd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001625ab4c 9. ./build_docker/./src/Disks/IO/AsynchronousBoundedReadBuffer.cpp:90: DB::AsynchronousBoundedReadBuffer::readAsync(char*, unsigned long, Priority) @ 0x00000000165218db 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousBoundedReadBuffer::prefetch(Priority) @ 0x0000000016521dcb 11. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::prefetch(Priority) @ 0x0000000016d5d6b7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bef531 13. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019bec888 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000019bec248 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019beccba 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:234: DB::MergeTreeSequentialSource::generate() @ 0x0000000019bf4ac2 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:555: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() @ 0x000000001996a4a2 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 29. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e53e16 30. ./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) @ 0x0000000019e5ab6b 31. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 2025.06.12 19:03:12.467766 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:12.557112 [ 4101 ] {taxnqxygfw} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50870) (comment: 02963_remote_read_small_buffer_size_bug.sh) (in query: WITH RANDOM_SET AS ( SELECT rand32() % 10000 FROM numbers(100) ) SELECT * FROM test WHERE a IN RANDOM_SET AND s IN ('x', 'y', 'z') FORMAT Null SETTINGS max_threads = 10, allow_prefetched_read_pool_for_remote_filesystem = 1, filesystem_prefetch_min_bytes_for_single_read_task = '1Ki', merge_tree_min_bytes_for_concurrent_read = 1, merge_tree_min_rows_for_concurrent_read = 1, merge_tree_min_bytes_for_concurrent_read_for_remote_filesystem = 1, merge_tree_min_rows_for_concurrent_read_for_remote_filesystem = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:12.558262 [ 4101 ] {taxnqxygfw} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:12.700367 [ 2746 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:13.294650 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:13.701061 [ 2731 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:14.130971 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:14.701796 [ 2711 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:14.877791 [ 4101 ] {14f4ec14-4475-47a5-a210-b271929a0241} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50930) (comment: 01804_dictionary_decimal256_type.sql) (in query: DROP DICTIONARY 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:14.878765 [ 4101 ] {14f4ec14-4475-47a5-a210-b271929a0241} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:14.979930 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:15.702710 [ 2692 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:15.838736 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:16.008568 [ 4101 ] {9d376292-27cb-46f2-8e74-018c2fbcd7dd} executeQuery: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50978) (comment: 02792_alter_table_modify_comment.sql) (in query: # Memory, MergeTree, and ReplicatedMergeTree CREATE TABLE t (x UInt8) ENGINE = Memory COMMENT 'Hello';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:16.009433 [ 4101 ] {9d376292-27cb-46f2-8e74-018c2fbcd7dd} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:16.704467 [ 3156 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:16.757088 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:17.502762 [ 4101 ] {989f614a-39c3-4955-8d05-c7f4f307241c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=768). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50992) (comment: 00189_time_zones_long.sql) (in query: SELECT toMonday(toDateTime(1419800400), 'Europe/Paris');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:17.503076 [ 4101 ] {989f614a-39c3-4955-8d05-c7f4f307241c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=768). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:17.610153 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:17.705187 [ 3142 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:18.506108 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:18.705917 [ 3121 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:19.209634 [ 4101 ] {bb6d2f36-7143-4ef1-9bb4-84d57048ed95} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'truetrue', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: while executing 'FUNCTION CAST(if(modulo(__table1.number, 2_UInt8), 'truetrue'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 1, 'Nullable(Bool)'_String :: 4) -> CAST(if(modulo(__table1.number, 2_UInt8), 'truetrue'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), 'Nullable(Bool)'_String) Nullable(Bool) : 3'. (CANNOT_PARSE_BOOL) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51030) (comment: 02303_cast_nullable_to_custom_types.sql) (in query: SELECT CAST(if(number % 2, 'truetrue', NULL), 'Nullable(Bool)') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x0000000007624bac 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000016f65291 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016f66c5a 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016fce203 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c3ce 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000778ae30 9. 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) @ 0x0000000007a2b748 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:19.210375 [ 4101 ] {bb6d2f36-7143-4ef1-9bb4-84d57048ed95} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'truetrue', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: while executing 'FUNCTION CAST(if(modulo(__table1.number, 2_UInt8), 'truetrue'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 1, 'Nullable(Bool)'_String :: 4) -> CAST(if(modulo(__table1.number, 2_UInt8), 'truetrue'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), 'Nullable(Bool)'_String) Nullable(Bool) : 3'. (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x0000000007624bac 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000016f65291 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016f66c5a 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016fce203 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c3ce 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000778ae30 9. 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) @ 0x0000000007a2b748 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:19.321524 [ 4101 ] {bbdd298d-9231-48c0-b347-01004a0abb77} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'falsefalse', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: while executing 'FUNCTION CAST(if(modulo(__table1.number, 2_UInt8), 'falsefalse'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 1, 'Nullable(Bool)'_String :: 4) -> CAST(if(modulo(__table1.number, 2_UInt8), 'falsefalse'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), 'Nullable(Bool)'_String) Nullable(Bool) : 3'. (CANNOT_PARSE_BOOL) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51030) (comment: 02303_cast_nullable_to_custom_types.sql) (in query: SELECT CAST(if(number % 2, 'falsefalse', NULL), 'Nullable(Bool)') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x0000000007624bac 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000016f65291 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016f66c5a 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016fce203 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c3ce 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000778ae30 9. 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) @ 0x0000000007a2b748 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:19.322315 [ 4101 ] {bbdd298d-9231-48c0-b347-01004a0abb77} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'falsefalse', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: while executing 'FUNCTION CAST(if(modulo(__table1.number, 2_UInt8), 'falsefalse'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 1, 'Nullable(Bool)'_String :: 4) -> CAST(if(modulo(__table1.number, 2_UInt8), 'falsefalse'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), 'Nullable(Bool)'_String) Nullable(Bool) : 3'. (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x0000000007624bac 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000016f65291 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016f66c5a 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016fce203 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000000776c3ce 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000778ae30 9. 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) @ 0x0000000007a2b748 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:19.331406 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:19.707205 [ 3090 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:19.886069 [ 4101 ] {5f7ac147-db62-4962-82f1-1a8e466b269b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51056) (comment: 03093_reading_bug_with_parallel_replicas.sql) (in query: insert into t2 select number from numbers_mt(1e6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:19.888426 [ 4101 ] {5f7ac147-db62-4962-82f1-1a8e466b269b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:20.196423 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:20.707958 [ 3068 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:20.816531 [ 4101 ] {65bcf99f-860e-4f6a-af62-7b012e270ba2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51092) (comment: 02494_query_cache_exception_handling.sql) (in query: -- If an exception is thrown during query execution, no entry must be created in the query cache SELECT throwIf(1) SETTINGS use_query_cache = true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3da96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:20.817086 [ 4101 ] {65bcf99f-860e-4f6a-af62-7b012e270ba2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3da96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:21.031805 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:21.708641 [ 3048 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:21.884429 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:22.435924 [ 4101 ] {71b1a2d2-3eaf-4689-b26e-c48934112409} executeQuery: Code: 182. DB::Exception: Table expression test_15.m AS __table1 does not support column __table1.a in PREWHERE. In query SELECT * FROM m PREWHERE a = 'OK'. (ILLEGAL_PREWHERE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41518) (comment: 02575_merge_prewhere_different_default_kind.sql) (in query: -- { echoOn } -- for pure PREWHERE it is not addressed yet. SELECT * FROM m PREWHERE a = 'OK';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017533514 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017533218 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017533218 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000017530c91 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dbf779 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:22.436677 [ 4101 ] {71b1a2d2-3eaf-4689-b26e-c48934112409} TCPHandler: Code: 182. DB::Exception: Table expression test_15.m AS __table1 does not support column __table1.a in PREWHERE. In query SELECT * FROM m PREWHERE a = 'OK'. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017533514 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017533218 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017533218 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000017530c91 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dbf779 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:22.709328 [ 3007 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:22.721817 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:23.292533 [ 4101 ] {6abf2fa8-27b7-4518-8da6-9f9d12ffa414} executeQuery: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007965927 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000000796556b 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&&) @ 0x00000000079578bd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.293276 [ 4101 ] {6abf2fa8-27b7-4518-8da6-9f9d12ffa414} TCPHandler: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007965927 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000000796556b 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&&) @ 0x00000000079578bd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.301669 [ 4101 ] {1098181f-7a1f-4559-86f5-0d74826f7cb1} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007965927 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000000796556b 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&&) @ 0x00000000079578bd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.302347 [ 4101 ] {1098181f-7a1f-4559-86f5-0d74826f7cb1} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007965927 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000000796556b 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&&) @ 0x00000000079578bd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.310269 [ 4101 ] {69efae13-d553-4b3f-849e-36d31b23a284} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000000796472c 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000079643d1 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&&) @ 0x0000000007950964 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.311254 [ 4101 ] {69efae13-d553-4b3f-849e-36d31b23a284} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000000796472c 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000079643d1 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&&) @ 0x0000000007950964 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.319565 [ 4101 ] {12e9a69d-c374-43b7-995f-97370d5c00db} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000000796472c 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000079643d1 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&&) @ 0x0000000007950964 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.320683 [ 4101 ] {12e9a69d-c374-43b7-995f-97370d5c00db} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000000796472c 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000079643d1 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&&) @ 0x0000000007950964 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.327842 [ 4101 ] {24830fa6-f49c-4c6f-a456-11e4d67bfc49} executeQuery: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate('2149-06-06'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x0000000007b610c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007963570 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007963211 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&&) @ 0x00000000079508e0 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.328277 [ 4101 ] {24830fa6-f49c-4c6f-a456-11e4d67bfc49} TCPHandler: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x0000000007b610c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007963570 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007963211 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&&) @ 0x00000000079508e0 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007940c16 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.334274 [ 4101 ] {e1c4b0df-b685-4605-b7cd-3c876c2ba38e} executeQuery: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x0000000007b75f71 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x0000000007b75be1 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&&) @ 0x0000000007a80cbd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.334984 [ 4101 ] {e1c4b0df-b685-4605-b7cd-3c876c2ba38e} TCPHandler: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x0000000007b75f71 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x0000000007b75be1 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&&) @ 0x0000000007a80cbd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.439121 [ 4101 ] {fe3f9587-6b00-4c69-9708-742de672c686} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x0000000007b75f71 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x0000000007b75be1 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&&) @ 0x0000000007a80cbd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.439804 [ 4101 ] {fe3f9587-6b00-4c69-9708-742de672c686} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x0000000007b61cc0 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x0000000007b75f71 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x0000000007b75be1 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&&) @ 0x0000000007a80cbd 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.446940 [ 4101 ] {cce43c7b-85cb-4a36-bb2e-1c3bf802be02} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007b73b0e 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007b737e4 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&&) @ 0x0000000007a7a579 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.447492 [ 4101 ] {cce43c7b-85cb-4a36-bb2e-1c3bf802be02} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007b73b0e 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007b737e4 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&&) @ 0x0000000007a7a579 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.455649 [ 4101 ] {edb821f3-bd83-45f0-98c3-b43588b6fcae} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41540) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007b73b0e 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007b737e4 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&&) @ 0x0000000007a7a579 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.456458 [ 4101 ] {edb821f3-bd83-45f0-98c3-b43588b6fcae} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000007b616c0 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000007b73b0e 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x0000000007b737e4 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&&) @ 0x0000000007a7a579 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a76f84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:03:23.573430 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:23.710099 [ 3049 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:24.392047 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:24.711071 [ 2999 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:25.213126 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:25.711900 [ 2957 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:25.905019 [ 4101 ] {c658066e-7a0d-4655-a231-74e54137f07f} 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.10057.altinitytest (altinity build)) 2025.06.12 19:03:25.990369 [ 4101 ] {c658066e-7a0d-4655-a231-74e54137f07f} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41580) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000195b1179 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:170: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000195ae736 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015e5b866 5. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e5ae12 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016233e40 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175ab3a1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749f920 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:25.991532 [ 4101 ] {c658066e-7a0d-4655-a231-74e54137f07f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000195b1179 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:170: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000195ae736 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015e5b866 5. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e5ae12 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016233e40 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175ab3a1 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749f920 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:26.105634 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:26.489666 [ 12086 ] {6f814b2f-322f-45e7-9bb8-c5e943db8548} 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.10057.altinitytest (altinity build)) 2025.06.12 19:03:26.712605 [ 2930 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:26.928446 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:26.931121 [ 4101 ] {d3ed8df2-59a5-481f-a6e0-b5468e16f819} 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.10057.altinitytest (altinity build)) 2025.06.12 19:03:26.952182 [ 3381 ] {d3ed8df2-59a5-481f-a6e0-b5468e16f819} 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.10057.altinitytest (altinity build)) 2025.06.12 19:03:27.713340 [ 2917 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:27.761233 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:28.572244 [ 4101 ] {69316a09-3865-4c21-a272-68c9893aadb6} 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.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46520) (comment: 02967_http_compressed.sh) (in query: SELECT 1,2,3,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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a5056b1 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a503fc5 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000001a506840 10. ./src/Processors/Formats/IOutputFormat.h:110: DB::IOutputFormat::work() @ 0x000000001a30126c 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:28.573435 [ 4101 ] {69316a09-3865-4c21-a272-68c9893aadb6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a5056b1 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a503fc5 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000001a506840 10. ./src/Processors/Formats/IOutputFormat.h:110: DB::IOutputFormat::work() @ 0x000000001a30126c 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:28.598844 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:28.714949 [ 2889 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:29.308578 [ 4101 ] {c91bebe0-6016-4784-95fe-5a497d5e9503} 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.10057.altinitytest (altinity build)) (from [::1]:41676) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000017c6743a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c38422 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c39856 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:29.309247 [ 4101 ] {c91bebe0-6016-4784-95fe-5a497d5e9503} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e120b06 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000017c6743a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c38422 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c39856 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:29.431288 [ 4101 ] {9a630b05-3963-4046-96b9-b26012832642} 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.10057.altinitytest (altinity build)) (from [::1]:41676) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Compression/CompressionCodecGCD.cpp:0: 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*) @ 0x0000000016dbef27 5. ./build_docker/./src/Compression/CompressionFactory.cpp:0: DB::CompressionCodecFactory::getImpl(String const&, std::shared_ptr const&, DB::IDataType const*) const @ 0x0000000016d68404 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000017c67a32 7. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000017c66451 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c38422 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c39856 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:29.432177 [ 4101 ] {9a630b05-3963-4046-96b9-b26012832642} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Compression/CompressionCodecGCD.cpp:0: 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*) @ 0x0000000016dbef27 5. ./build_docker/./src/Compression/CompressionFactory.cpp:0: DB::CompressionCodecFactory::getImpl(String const&, std::shared_ptr const&, DB::IDataType const*) const @ 0x0000000016d68404 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000017c67a32 7. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000017c66451 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c38422 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c39856 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:29.452015 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:29.715921 [ 3145 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:30.280075 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:30.716599 [ 2858 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:31.084320 [ 5779 ] {17e2d83f-5827-4900-8f88-1439cb6029f0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=768). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41734) (comment: 03167_parametrized_view_with_cte.sql) (in query: WITH (SELECT 123) AS s SELECT * FROM param_test(test_str=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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:31.085008 [ 5779 ] {17e2d83f-5827-4900-8f88-1439cb6029f0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=768). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:31.124113 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:31.717384 [ 2826 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:31.960592 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:32.222233 [ 5779 ] {277ed061-b6a6-4310-be9a-8cfff129ae99} executeQuery: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41754) (comment: 02520_group_array_last.sql) (in query: -- { echo } -- BAD_ARGUMENTS select groupArrayLast(number+1) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:797: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013cd033c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 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 @ 0x00000000162292ab 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:32.251719 [ 5779 ] {277ed061-b6a6-4310-be9a-8cfff129ae99} TCPHandler: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:797: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013cd033c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 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 @ 0x00000000162292ab 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:32.601630 [ 5779 ] {17722af8-3ba7-44d4-9aac-6a86e762c39b} executeQuery: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41754) (comment: 02520_group_array_last.sql) (in query: select groupArrayLastArray([number+1]) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:797: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013cd033c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 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 @ 0x00000000162292ab 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b18b 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 @ 0x00000000162292ab 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:32.602253 [ 5779 ] {17722af8-3ba7-44d4-9aac-6a86e762c39b} TCPHandler: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:797: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013cd033c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 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 @ 0x00000000162292ab 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b18b 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 @ 0x00000000162292ab 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:32.717977 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:32.803941 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.317209 [ 4083 ] {eff689f5-a5d5-4b45-babc-39a5e121d844} executeQuery: Code: 582. DB::Exception: There is no projection pp in table. (NO_SUCH_PROJECTION_IN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45976) (comment: 01710_projection_drop_if_exists.sql) (in query: alter table tp drop projection pp;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:0: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000019165c56 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190d5f2d 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190dd799 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199db494 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.317748 [ 4083 ] {eff689f5-a5d5-4b45-babc-39a5e121d844} TCPHandler: Code: 582. DB::Exception: There is no projection pp in table. (NO_SUCH_PROJECTION_IN_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:0: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000019165c56 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190d5f2d 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190dd799 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199db494 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.370689 [ 4083 ] {b07c785c-9c45-49fc-ab73-c6cfb9aca2c7} executeQuery: Code: 582. DB::Exception: There is no projection p in table. (NO_SUCH_PROJECTION_IN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45976) (comment: 01710_projection_drop_if_exists.sql) (in query: alter table tp drop projection p;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:0: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000019165c56 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190d5f2d 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190dd799 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199db494 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.371424 [ 4083 ] {b07c785c-9c45-49fc-ab73-c6cfb9aca2c7} TCPHandler: Code: 582. DB::Exception: There is no projection p in table. (NO_SUCH_PROJECTION_IN_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:0: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000019165c56 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190d5f2d 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190dd799 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199db494 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.686247 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.719000 [ 2770 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:33.855756 [ 4101 ] {5f9957e6-edf4-428c-8432-d7b0d90b8696} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/store/9dd/9dd6d807-b7b0-42bb-b025-1023d3191e7e//data.TSV doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45994) (comment: 01720_engine_file_empty_if_not_exists.sql) (in query: SELECT * FROM file_engine_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 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) @ 0x00000000191cdc80 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) @ 0x0000000017de89e1 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.856328 [ 4101 ] {5f9957e6-edf4-428c-8432-d7b0d90b8696} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/store/9dd/9dd6d807-b7b0-42bb-b025-1023d3191e7e//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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 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) @ 0x00000000191cdc80 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) @ 0x0000000017de89e1 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.866443 [ 4101 ] {bd3cc0f6-78e9-4a9f-a13f-1dcde4f57d2c} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/store/9dd/9dd6d807-b7b0-42bb-b025-1023d3191e7e//data.TSV doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45994) (comment: 01720_engine_file_empty_if_not_exists.sql) (in query: SELECT * FROM file_engine_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 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) @ 0x00000000191cdc80 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) @ 0x0000000017de89e1 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:33.867047 [ 4101 ] {bd3cc0f6-78e9-4a9f-a13f-1dcde4f57d2c} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/store/9dd/9dd6d807-b7b0-42bb-b025-1023d3191e7e//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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 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) @ 0x00000000191cdc80 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) @ 0x0000000017de89e1 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:34.514463 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:34.719752 [ 2752 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:35.476462 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:35.601435 [ 3280 ] {718106a1-7a30-4c5e-bf99-eb96e4fa7e29::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:35.601995 [ 3280 ] {718106a1-7a30-4c5e-bf99-eb96e4fa7e29::all_1_1_0_2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:35.602307 [ 4101 ] {9ea92cc1-a8a6-4165-af68-af38d547ba34} 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=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.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.10057.altinitytest (altinity build)) (from [::1]:46026) (comment: 03198_unload_primary_key_outdated.sh) (in query: ALTER TABLE t_unload_primary_key UPDATE b = 100 WHERE 1 SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019b98254 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019b9815c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e4a360 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b7c2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:35.603569 [ 4101 ] {9ea92cc1-a8a6-4165-af68-af38d547ba34} 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=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019b98254 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019b9815c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e4a360 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b7c2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:35.720438 [ 2717 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:35.809113 [ 4101 ] {a47c308c-795d-4a1f-b5f4-9a7d94069437} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=768). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46054) (comment: 00719_insert_block_without_column.sh) (in query: select number as SomeID, number+1 as OtherID from system.numbers limit 1000 into outfile '/tmp/clickhouse-test/0_stateless/test_squashing_block_without_column.out' format Native), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:35.809997 [ 4101 ] {a47c308c-795d-4a1f-b5f4-9a7d94069437} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=768). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:36.369826 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:36.721105 [ 2688 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:37.034710 [ 4101 ] {3948112c-4dda-476b-927c-0c1bdf83db0f} executeQuery: Code: 59. DB::Exception: Illegal type Float64 of column modulo(sipHash64(sipHash64(p, toString(toDate(p))), toString(toDate(p))), -0._Float64) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46096) (comment: 02680_illegal_type_of_filter_projection.sql) (in query: SELECT count() FROM test_tuple PREWHERE sipHash64(sipHash64(p, toString(toDate(p))), toString(toDate(p))) % -0. WHERE i > NULL settings optimize_trivial_count_query=0, optimize_use_implicit_projections=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000824d126 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:0: DB::QueryPlanOptimizations::findInOutputs(DB::ActionsDAG&, String const&, bool) @ 0x000000001aa25fd2 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:140: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000001aa264fc 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:151: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000001aa261a2 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:151: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000001aa261a2 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:185: DB::QueryPlanOptimizations::QueryDAG::build(DB::QueryPlan::Node&) @ 0x000000001aa26704 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:456: DB::QueryPlanOptimizations::getAggregateProjectionCandidates(DB::QueryPlan::Node&, DB::AggregatingStep&, DB::ReadFromMergeTree&, std::shared_ptr, std::equal_to, std::allocator>>> const&, bool) @ 0x000000001aa17921 10. ./src/Processors/QueryPlan/ReadFromMergeTree.h:187: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1a4ae 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:37.035441 [ 4101 ] {3948112c-4dda-476b-927c-0c1bdf83db0f} TCPHandler: Code: 59. DB::Exception: Illegal type Float64 of column modulo(sipHash64(sipHash64(p, toString(toDate(p))), toString(toDate(p))), -0._Float64) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000824d126 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:0: DB::QueryPlanOptimizations::findInOutputs(DB::ActionsDAG&, String const&, bool) @ 0x000000001aa25fd2 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:140: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000001aa264fc 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:151: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000001aa261a2 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:151: DB::QueryPlanOptimizations::QueryDAG::buildImpl(DB::QueryPlan::Node&, std::vector>&) @ 0x000000001aa261a2 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:185: DB::QueryPlanOptimizations::QueryDAG::build(DB::QueryPlan::Node&) @ 0x000000001aa26704 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:456: DB::QueryPlanOptimizations::getAggregateProjectionCandidates(DB::QueryPlan::Node&, DB::AggregatingStep&, DB::ReadFromMergeTree&, std::shared_ptr, std::equal_to, std::allocator>>> const&, bool) @ 0x000000001aa17921 10. ./src/Processors/QueryPlan/ReadFromMergeTree.h:187: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1a4ae 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:37.271150 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:37.721802 [ 3161 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:38.104951 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:38.404001 [ 4101 ] {f490508f-1d73-449e-9861-a798575d8bad} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-1e-7). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46128) (comment: 03213_rand_dos.sql) (in query: SELECT randChiSquared(-0.0000001);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e030bfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:38.404672 [ 4101 ] {f490508f-1d73-449e-9861-a798575d8bad} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-1e-7). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e030bfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:38.411169 [ 4101 ] {2e362027-3cf6-4e20-9cf1-940f189f3a49} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-0.). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46128) (comment: 03213_rand_dos.sql) (in query: SELECT randChiSquared(-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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e030bfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:38.411643 [ 4101 ] {2e362027-3cf6-4e20-9cf1-940f189f3a49} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e030bfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:38.623001 [ 4101 ] {df85c71a-0ae6-4654-b1a3-3e2d072e470d} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randStudentT should be greater than zero: In scope SELECT randStudentT(-0.). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46128) (comment: 03213_rand_dos.sql) (in query: SELECT randStudentT(-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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e031977 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:38.623646 [ 4101 ] {df85c71a-0ae6-4654-b1a3-3e2d072e470d} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randStudentT should be greater than zero: In scope SELECT randStudentT(-0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e031977 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:38.722843 [ 3124 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:38.919050 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:39.014239 [ 4101 ] {94bee97d-fa8f-4c18-ae2f-a2807ce7258d} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(-0., 1). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46128) (comment: 03213_rand_dos.sql) (in query: SELECT randFisherF(-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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0324fa 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:39.015216 [ 4101 ] {94bee97d-fa8f-4c18-ae2f-a2807ce7258d} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(-0., 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0324fa 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:39.023191 [ 4101 ] {ff643a3a-c04a-45d3-9307-f17e753f5403} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(1, -0.). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46128) (comment: 03213_rand_dos.sql) (in query: SELECT randFisherF(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0324fa 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:39.023827 [ 4101 ] {ff643a3a-c04a-45d3-9307-f17e753f5403} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(1, -0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0324fa 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:03:39.723555 [ 3192 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:39.744970 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:40.526667 [ 4101 ] {ddd58e5a-0afb-46e5-8555-4e5c9503aec9} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `VasyaUnexistingColumn` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46218) (comment: 00446_clear_column_in_partition_concurrent_zookeeper.sh) (in query: ALTER TABLE clear_column1 CLEAR COLUMN VasyaUnexistingColumn IN PARTITION '200001'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190e4316 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2072b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:40.527840 [ 4101 ] {ddd58e5a-0afb-46e5-8555-4e5c9503aec9} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `VasyaUnexistingColumn` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190e4316 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2072b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:40.651235 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:40.724250 [ 3038 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:41.492669 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:41.724970 [ 3185 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:42.335261 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:42.743907 [ 2863 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.160217 [ 4101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:43.258240 [ 3334 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.259409 [ 2808 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:03:43.259623 [ 2814 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:03:43.259815 [ 3129 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:03:43.260102 [ 2978 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:03:43.260279 [ 2807 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:03:43.260849 [ 2804 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:03:43.261115 [ 2801 ] {} test_9.test (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:03:43.261422 [ 2803 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:03:43.369623 [ 3268 ] {b3a76e2b-dbbf-4574-980d-021aec1f5b11::20000201_20000201_2_2_0_3} auto DB::ReplicatedMergeMutateTaskBase::executeImpl()::(anonymous class)::operator()() const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/1/queue/queue-0000000014. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:556: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add24d5 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:592: DB::ReplicatedMergeTreeQueue::removeProcessedEntry(std::shared_ptr, std::shared_ptr&) @ 0x0000000019d80c0f 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:149: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_0::operator()() const @ 0x0000000019d36c81 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a21 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.455885 [ 2802 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.455901 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.461024 [ 2809 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/2/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cf7ec 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.468963 [ 3849 ] {dac939de-49bf-4cd1-905b-88bdf7c22eff} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40296) (comment: 00446_clear_column_in_partition_concurrent_zookeeper.sh) (in query: ALTER TABLE clear_column1 CLEAR COLUMN i IN PARTITION '200002'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:686: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x0000000019358557 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000194098bf 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000194072bf 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c207bf 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:43.470037 [ 3849 ] {dac939de-49bf-4cd1-905b-88bdf7c22eff} TCPHandler: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:686: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x0000000019358557 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000194098bf 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000194072bf 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c207bf 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:43.497239 [ 2813 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.497360 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.610076 [ 2815 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x0000000018209f6e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000018209c2c 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::BaseMergePredicate::getCommittingBlocks(std::shared_ptr&, String const&, std::shared_ptr) @ 0x0000000019db4e23 9. ./contrib/llvm-project/libcxx/include/new:246: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac3b3 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReplicatedMergeTreeQueue::tryFinalizeMutations(std::shared_ptr) @ 0x0000000019da5cfe 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3968: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06b2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.610097 [ 2818 ] {} test_9.clear_column1 (b3a76e2b-dbbf-4574-980d-021aec1f5b11): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x0000000018209f6e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000018209c2c 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::BaseMergePredicate::getCommittingBlocks(std::shared_ptr&, String const&, std::shared_ptr) @ 0x0000000019db4e23 9. ./contrib/llvm-project/libcxx/include/new:246: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac3b3 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReplicatedMergeTreeQueue::tryFinalizeMutations(std::shared_ptr) @ 0x0000000019da5cfe 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3968: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06b2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:43.744723 [ 2725 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:44.007814 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:44.456714 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:44.745642 [ 2691 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:44.832041 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:45.457637 [ 3127 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:45.502136 [ 4083 ] {c31a292f-b6c5-446a-a857-bdee728610e4} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40374) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: drop table if exists view_00840;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:45.502975 [ 4083 ] {c31a292f-b6c5-446a-a857-bdee728610e4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:45.716495 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:45.746397 [ 3095 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:45.932620 [ 3313 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:46.458688 [ 3075 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:46.535042 [ 3826 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:46.567708 [ 3310 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:46.747385 [ 3064 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:47.018263 [ 3314 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:47.267239 [ 3314 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:47.419124 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:47.459407 [ 3041 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:47.585893 [ 3311 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:47.716188 [ 3315 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:47.748194 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:48.258261 [ 3826 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:48.270669 [ 3314 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:48.325953 [ 3310 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:48.460119 [ 3072 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:48.748914 [ 2954 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:49.161321 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:49.189252 [ 3315 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 710. DB::Exception: Injecting fault for log entry ALTER_METADATA with virtual parts []. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c7f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 9. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:49.461080 [ 3045 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:49.749726 [ 3190 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:49.980394 [ 3826 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:50.462018 [ 2887 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:50.750366 [ 2890 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:50.893611 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:51.462891 [ 2965 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:51.718837 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:51.803955 [ 2858 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:52.021025 [ 3966 ] {1e4998dd-42a9-464d-8b5e-56192164f78c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42382) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:52.022115 [ 3966 ] {1e4998dd-42a9-464d-8b5e-56192164f78c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:52.463489 [ 2847 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:52.672144 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:52.804562 [ 2831 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:53.464214 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:53.538048 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:53.805286 [ 2767 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:53.810957 [ 3966 ] {322c6ec7-0d36-46db-a5b6-cbcfb53a7504} 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.10057.altinitytest (altinity build)) (from [::1]:42436) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:53.812657 [ 3966 ] {322c6ec7-0d36-46db-a5b6-cbcfb53a7504} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001a6ac8d9 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:54.370014 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:54.465480 [ 2792 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:54.806085 [ 2775 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:55.194850 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:55.466356 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:55.806996 [ 2745 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:56.024939 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:56.026449 [ 3849 ] {5bbaf062-6c00-4f8c-af47-340f8eb1b470} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42516) (comment: 02887_mutations_subcolumns.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:56.027656 [ 3849 ] {5bbaf062-6c00-4f8c-af47-340f8eb1b470} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:56.467005 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:56.807668 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:56.892568 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:57.467981 [ 2693 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:57.769857 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:57.808454 [ 2682 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:58.043979 [ 3966 ] {97923fd3-751e-4208-8374-76d359bdc42b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33080) (comment: 02136_scalar_progress.sh) (in query: SELECT (SELECT max(number), count(number) FROM numbers(100000) settings max_block_size=65505);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:58.045175 [ 3966 ] {97923fd3-751e-4208-8374-76d359bdc42b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:58.468642 [ 3151 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:58.600843 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:58.809249 [ 3137 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:59.435653 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:59.466083 [ 3966 ] {5a8968d9-919a-476a-87f5-7840654536b0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=768). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42602) (comment: 02403_enable_extended_results_for_datetime_functions.gen.sql) (in query: SELECT 'toStartOfHour;toDateTime64;true', toStartOfHour(toDateTime64('1920-02-02 10:23:33.789', 3, 'UTC'), 'UTC') SETTINGS enable_extended_results_for_datetime_functions = true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:59.467227 [ 3966 ] {5a8968d9-919a-476a-87f5-7840654536b0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=768). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:03:59.469363 [ 3126 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:03:59.809949 [ 3090 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:00.256654 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:00.470097 [ 3094 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:00.811137 [ 3089 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:01.156988 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:01.471202 [ 3074 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:01.811941 [ 3059 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:01.974919 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:02.472018 [ 3037 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:02.806377 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:02.813052 [ 3034 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:03.472781 [ 3193 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:03.642052 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:03.813941 [ 2997 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:04.473446 [ 2979 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:04.499253 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:04.861360 [ 2967 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:04.993201 [ 4203 ] {84fb729c-eb3b-4df2-a90f-e545f146eb8b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32962) (comment: 02967_parallel_replicas_joins_and_analyzer.gen.sql) (in query: DROP DATABASE IF EXISTS test_dcrfcamu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:04.994419 [ 4203 ] {84fb729c-eb3b-4df2-a90f-e545f146eb8b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:05.362417 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:05.474101 [ 2947 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:05.862288 [ 2935 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:06.200487 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:06.485921 [ 3196 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:06.863333 [ 2923 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:07.052846 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:07.486901 [ 2901 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:07.864096 [ 2898 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:07.885987 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:08.487721 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:08.704847 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:08.864778 [ 2895 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:09.488394 [ 2981 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:09.615180 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:09.865523 [ 2858 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:10.456119 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:10.489066 [ 2855 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:10.866198 [ 2841 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:11.297928 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:11.489884 [ 3030 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:11.867179 [ 2829 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:12.128705 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:12.491023 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:12.867989 [ 3138 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:13.050403 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:13.491805 [ 2776 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:13.498333 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {efc9ab92-e475-4973-9a01-6dd22a9c9450::202506_1_83_16}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:13.868813 [ 2802 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:13.884877 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:14.492680 [ 2815 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:14.709978 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:14.869533 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:15.493583 [ 2727 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:15.574720 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:15.870169 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:16.435101 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:16.494384 [ 2722 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:16.582123 [ 5779 ] {7c32425b-de13-4c9e-93bf-a1075905403b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44686) (comment: 02476_fuse_sum_count.sql) (in query: SELECT sum(a + 1), sum(b), count(b), avg(b), count(a + 1), sum(a + 2), count(a) from fuse_tbl SETTINGS optimize_syntax_fuse_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:16.583679 [ 5779 ] {7c32425b-de13-4c9e-93bf-a1075905403b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:16.870975 [ 2705 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:17.276306 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:17.495375 [ 2688 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:17.872077 [ 3158 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:18.255089 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:18.496201 [ 3149 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:18.872923 [ 3140 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:19.086960 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:19.497282 [ 3118 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:19.873590 [ 3106 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:19.965753 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:20.499061 [ 3113 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:20.804823 [ 4203 ] {56f8e0a4-6aa0-49f4-971a-2866e5840aef} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44730) (comment: 02188_parser_dictionary_primary_key.sql) (in query: DROP DICTIONARY 02188_test_dictionary_simple_primary_key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:20.806259 [ 4203 ] {56f8e0a4-6aa0-49f4-971a-2866e5840aef} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:20.848737 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:20.874199 [ 3095 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:21.499911 [ 3080 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:21.720819 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:21.875041 [ 3065 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:22.500644 [ 3058 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:22.570077 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:22.876023 [ 3054 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:23.475270 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:23.501552 [ 3020 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:23.876699 [ 3005 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:24.370150 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:24.408298 [ 3849 ] {49cbc58c-1499-4dae-bc7c-8a89eb22a037} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 512.70 MiB (attempt to allocate chunk of 134479872 bytes), maximum: 476.84 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42684) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (in query: select key, groupArray(repeat('a', 200)), count() from data_01513 group by key format Null settings optimize_aggregation_in_order=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9bd41a 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000888030e 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x0000000008880056 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000013d4d731 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1226: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000017741bfe 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch>, false>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x00000000179101d9 13. ./build_docker/./src/Interpreters/Aggregator.cpp:874: void DB::Aggregator::executeImpl>, false>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001790da00 14. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl>, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x00000000177ffd74 15. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001773e8fa 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: 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 @ 0x000000001774507a 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001a65e8fe 18. ./contrib/llvm-project/libcxx/include/vector:438: DB::AggregatingTransform::work() @ 0x000000001a65aab3 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:24.502948 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:24.572150 [ 3849 ] {49cbc58c-1499-4dae-bc7c-8a89eb22a037} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 512.70 MiB (attempt to allocate chunk of 134479872 bytes), maximum: 476.84 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9bd41a 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000888030e 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x0000000008880056 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000013d4d731 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1226: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000017741bfe 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch>, false>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x00000000179101d9 13. ./build_docker/./src/Interpreters/Aggregator.cpp:874: void DB::Aggregator::executeImpl>, false>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001790da00 14. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl>, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x00000000177ffd74 15. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001773e8fa 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: 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 @ 0x000000001774507a 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001a65e8fe 18. ./contrib/llvm-project/libcxx/include/vector:438: DB::AggregatingTransform::work() @ 0x000000001a65aab3 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:24.877415 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:25.261273 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:25.503955 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:25.878571 [ 2957 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:26.142576 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:26.505120 [ 2951 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:26.879318 [ 2930 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:27.026681 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:27.506079 [ 2939 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:27.880199 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:27.951333 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:28.506859 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:28.813285 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:28.880908 [ 2883 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:29.507703 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:29.655289 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:29.881618 [ 2865 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:30.482376 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:30.508510 [ 2849 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:30.882467 [ 2836 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:31.302570 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:31.509633 [ 2825 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:31.884025 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:32.167335 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:32.510669 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:32.884827 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:33.048690 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:33.474728 [ 4203 ] {85dcdc72-4433-4ce3-b125-1e4408ffa160} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60714) (comment: 03164_selects_with_pk_usage_profile_event.sh) (in query: SELECT ProfileEvents['SelectQueriesWithPrimaryKeyUsage'] AS selects_with_pk_usage FROM system.query_log WHERE current_database = currentDatabase() AND type = 'QueryFinish' AND query_id = 'blmdagcrin' FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:04:33.477674 [ 4203 ] {85dcdc72-4433-4ce3-b125-1e4408ffa160} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:04:33.511518 [ 2770 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:33.885825 [ 2744 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:33.886777 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:34.512319 [ 2730 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:34.801200 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:34.886851 [ 2715 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:35.513322 [ 2699 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:35.694423 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:35.887558 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:36.514178 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:36.587759 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:36.888337 [ 3195 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:37.422077 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:37.515253 [ 3161 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:37.888997 [ 2704 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:38.326644 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:38.515985 [ 3120 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:38.678183 [ 3966 ] {a1abb5fa-1e42-4fac-a5bc-46df7ee3b331} executeQuery: Code: 36. DB::Exception: Cannot load time zone not a timezone: In scope SELECT makeDateTime(1984, 1, 1, 0, 0, 0, 'not a timezone'). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38644) (comment: 02244_make_datetime.sql) (in query: select makeDateTime(1984, 1, 1, 0, 0, 0, 'not a timezone');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000f9eab08 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000000f9e54e7 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000016e3d935 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x0000000016e3d47e 8. std::shared_ptr std::allocate_shared[abi:v15007], String&, void>(std::allocator const&, String&) @ 0x000000000944b382 9. DB::(anonymous namespace)::FunctionMakeDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b0d47 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:04:38.678942 [ 3966 ] {a1abb5fa-1e42-4fac-a5bc-46df7ee3b331} TCPHandler: Code: 36. DB::Exception: Cannot load time zone not a timezone: In scope SELECT makeDateTime(1984, 1, 1, 0, 0, 0, 'not a timezone'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000f9eab08 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000000f9e54e7 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000016e3d935 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x0000000016e3d47e 8. std::shared_ptr std::allocate_shared[abi:v15007], String&, void>(std::allocator const&, String&) @ 0x000000000944b382 9. DB::(anonymous namespace)::FunctionMakeDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b0d47 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:04:38.889672 [ 3115 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:39.157052 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:39.516823 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:39.583901 [ 3966 ] {091972d9-5508-46cc-8efb-25762f78a627} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38660) (comment: 01280_min_map_max_map.sql) (in query: select maxMap([1], [toInt32(number) - 50]) from numbers(1, 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:39.584642 [ 3966 ] {091972d9-5508-46cc-8efb-25762f78a627} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:39.890707 [ 3088 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:39.975398 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:40.468193 [ 3966 ] {7ddeae5d-e05f-44c5-a393-e2bd95494b2d} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope (SELECT toDecimal128([], rowNumberInBlock())). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38668) (comment: 00811_garbage.sql) (in query: SELECT ( SELECT toDecimal128([], rowNumberInBlock()) ) , lcm('', [[(CAST(('>A') AS String))]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 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&&) @ 0x0000000007647b3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007644ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764481e 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&) @ 0x0000000007a64758 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007a52d8c 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499a1d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 2025.06.12 19:04:40.468913 [ 3966 ] {7ddeae5d-e05f-44c5-a393-e2bd95494b2d} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope (SELECT toDecimal128([], rowNumberInBlock())). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 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&&) @ 0x0000000007647b3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007644ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764481e 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&) @ 0x0000000007a64758 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007a52d8c 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499a1d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 2025.06.12 19:04:40.517756 [ 3073 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:40.830669 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:40.891362 [ 3066 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:41.518722 [ 3063 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:41.640175 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:41.892119 [ 3054 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:42.266340 [ 3966 ] {cbf6a618-8595-4db6-8a66-4b834cae6022} executeQuery: Code: 169. DB::Exception: ASOF join not supported for type: String. (BAD_TYPE_OF_FIELD) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38700) (comment: 01139_asof_join_types.sql) (in query: select * from (select 0 as k, 'x' as v) t1 asof join (select 0 as k, 'x' as v) t2 using(k, v);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/RowRefs.cpp:0: DB::SortedLookupVectorBase::getTypeSize(DB::IColumn const&, unsigned long&) @ 0x00000000183b4f50 5. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x0000000018352f94 6. ./contrib/llvm-project/libcxx/include/string:1499: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x0000000017700700 7. ./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&) @ 0x0000000017e11d4d 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df0110 9. ./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&) @ 0x0000000017de0b12 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:42.267571 [ 3966 ] {cbf6a618-8595-4db6-8a66-4b834cae6022} TCPHandler: Code: 169. DB::Exception: ASOF join not supported for type: String. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/RowRefs.cpp:0: DB::SortedLookupVectorBase::getTypeSize(DB::IColumn const&, unsigned long&) @ 0x00000000183b4f50 5. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x0000000018352f94 6. ./contrib/llvm-project/libcxx/include/string:1499: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x0000000017700700 7. ./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&) @ 0x0000000017e11d4d 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df0110 9. ./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&) @ 0x0000000017de0b12 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:42.457588 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:42.519877 [ 3027 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:42.893243 [ 3007 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:43.000158 [ 3966 ] {5555ae9e-238c-4bc7-a579-3b85d62bfe2f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50268) (comment: 01323_add_scalars_in_time.sql) (in query: SELECT column, (SELECT d from (select [1, 2, 3, 4] as d)) as d FROM TestTable where column == 'test' GROUP BY 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:43.001086 [ 3966 ] {5555ae9e-238c-4bc7-a579-3b85d62bfe2f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:43.337151 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:43.387841 [ 3849 ] {5a1a5c69-947e-4bc8-9539-ef29adec699c} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 488.35 MiB (attempt to allocate chunk of 16783360 bytes), maximum: 476.84 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42684) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (in query: select key, groupArray(repeat('a', 200)), count() from data_01513 group by key format Null settings optimize_aggregation_in_order=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000f9bd8e0 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000007622aa4 9. ./src/Common/PODArray.h:315: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000018cf329d 10. DB::IColumn::insertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000007b38963 11. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000018ab886f 12. DB::IColumn::insertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000007b38963 13. ./build_docker/./src/Processors/Chunk.cpp:0: DB::Chunk::append(DB::Chunk const&, unsigned long, unsigned long) @ 0x000000001a2bc564 14. ./build_docker/./src/Interpreters/Cache/QueryCache.cpp:416: DB::QueryCache::Writer::finalizeWrite() @ 0x000000001832f5e7 15. ./build_docker/./src/Processors/Transforms/StreamInQueryCacheTransform.cpp:25: DB::StreamInQueryCacheTransform::finalizeWriteInQueryCache() @ 0x000000001a7423e0 16. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:657: DB::QueryPipeline::finalizeWriteInQueryCache() @ 0x0000000016ddf755 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: void std::__function::__policy_invoker::__call_impl, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_1, void (DB::QueryPipeline&)>>(std::__function::__policy_storage const*, DB::QueryPipeline&) @ 0x00000000182206cb 18. ./build_docker/./src/QueryPipeline/BlockIO.cpp:59: DB::BlockIO::onFinish() @ 0x0000000016dc43fc 19. ./build_docker/./src/Server/TCPHandler.cpp:579: DB::TCPHandler::runImpl() @ 0x000000001a1d8fbf 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:43.520606 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:43.572890 [ 3849 ] {5a1a5c69-947e-4bc8-9539-ef29adec699c} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 488.35 MiB (attempt to allocate chunk of 16783360 bytes), maximum: 476.84 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000f9bd8e0 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000007622aa4 9. ./src/Common/PODArray.h:315: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000018cf329d 10. DB::IColumn::insertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000007b38963 11. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000018ab886f 12. DB::IColumn::insertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000007b38963 13. ./build_docker/./src/Processors/Chunk.cpp:0: DB::Chunk::append(DB::Chunk const&, unsigned long, unsigned long) @ 0x000000001a2bc564 14. ./build_docker/./src/Interpreters/Cache/QueryCache.cpp:416: DB::QueryCache::Writer::finalizeWrite() @ 0x000000001832f5e7 15. ./build_docker/./src/Processors/Transforms/StreamInQueryCacheTransform.cpp:25: DB::StreamInQueryCacheTransform::finalizeWriteInQueryCache() @ 0x000000001a7423e0 16. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:657: DB::QueryPipeline::finalizeWriteInQueryCache() @ 0x0000000016ddf755 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: void std::__function::__policy_invoker::__call_impl, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_1, void (DB::QueryPipeline&)>>(std::__function::__policy_storage const*, DB::QueryPipeline&) @ 0x00000000182206cb 18. ./build_docker/./src/QueryPipeline/BlockIO.cpp:59: DB::BlockIO::onFinish() @ 0x0000000016dc43fc 19. ./build_docker/./src/Server/TCPHandler.cpp:579: DB::TCPHandler::runImpl() @ 0x000000001a1d8fbf 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:43.893994 [ 2967 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:44.165268 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:44.521397 [ 2959 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:44.895113 [ 2947 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:45.038778 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:45.522208 [ 2929 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:45.856891 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:45.896024 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:46.522900 [ 2923 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:46.686885 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:46.896694 [ 2911 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:47.029454 [ 5779 ] {312924d9-05c6-4e7d-b889-4d0f88aaef33} executeQuery: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.test_table. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50380) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_9.test_view_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:47.073271 [ 5779 ] {312924d9-05c6-4e7d-b889-4d0f88aaef33} TCPHandler: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:47.523599 [ 2889 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:47.523623 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:47.897414 [ 2890 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:48.258102 [ 5779 ] {6c287c8c-97ea-4aee-a7a6-aa067b8fd93a} executeQuery: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.test_table. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50454) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_9.test_view_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:48.259470 [ 5779 ] {6c287c8c-97ea-4aee-a7a6-aa067b8fd93a} TCPHandler: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:48.524224 [ 3170 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:48.566011 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:48.635935 [ 5779 ] {3878f020-7324-4e62-af54-4bde499c9cc8} executeQuery: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.test_table. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50488) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_9.test_view_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:48.637393 [ 5779 ] {3878f020-7324-4e62-af54-4bde499c9cc8} TCPHandler: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:48.898443 [ 2862 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:49.413883 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:49.525036 [ 2846 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:49.853767 [ 5779 ] {fba646de-5203-450f-991c-687f1303e462} executeQuery: Code: 497. DB::Exception: user02884_3_test_9_10112: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.test_table. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50556) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_9.test_view_8), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:49.854736 [ 5779 ] {fba646de-5203-450f-991c-687f1303e462} TCPHandler: Code: 497. DB::Exception: user02884_3_test_9_10112: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:49.867352 [ 4203 ] {fe2de1e1-8036-4db0-a4a7-250110f0d5cb} executeQuery: Code: 57. DB::Exception: Table test_15.tbl already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50558) (comment: 02047_log_family_data_file_dumps.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:49.868067 [ 4203 ] {fe2de1e1-8036-4db0-a4a7-250110f0d5cb} TCPHandler: Code: 57. DB::Exception: Table test_15.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:49.899624 [ 2841 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:50.236922 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:50.526111 [ 2822 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:50.900511 [ 2828 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:51.061601 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:51.527483 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:51.889432 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:51.901408 [ 2785 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:52.200543 [ 5779 ] {1909c9ba-61c8-470e-ab34-a78d8efd3c7f} executeQuery: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.test_table. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42976) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_9.test_view_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:52.202840 [ 5779 ] {1909c9ba-61c8-470e-ab34-a78d8efd3c7f} TCPHandler: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./contrib/llvm-project/libcxx/include/__hash_table:92: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017ddf1d6 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de470b 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000017dba2db 17. ./build_docker/./src/Storages/StorageView.cpp:171: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001957f7d0 18. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000017de89e1 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1801: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de0610 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 21. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 22. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:04:52.528374 [ 2764 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:52.715242 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:52.902168 [ 2773 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:53.151655 [ 4203 ] {7132fc5a-4e02-4e9e-bc4c-d88a3b3e7e24} executeQuery: Code: 57. DB::Exception: Table test_15.tbl already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43042) (comment: 02047_log_family_data_file_dumps.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:53.152513 [ 4203 ] {7132fc5a-4e02-4e9e-bc4c-d88a3b3e7e24} TCPHandler: Code: 57. DB::Exception: Table test_15.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:53.529156 [ 2757 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:53.546246 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:53.685036 [ 5779 ] {1795b867-7f51-400d-a6d7-edd00b6375c2} executeQuery: Code: 397. DB::Exception: SQL SECURITY INVOKER can't be specified for MATERIALIZED VIEW. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43050) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE MATERIALIZED VIEW test_9.test_mv_2 (s String) ENGINE = MergeTree ORDER BY s SQL SECURITY INVOKER AS SELECT * FROM test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageMaterializedView.cpp:102: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000192aac49 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::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000192b573e 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:733: 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&) @ 0x00000000192b4351 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 @ 0x00000000191ba866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:53.686181 [ 5779 ] {1795b867-7f51-400d-a6d7-edd00b6375c2} TCPHandler: Code: 397. DB::Exception: SQL SECURITY INVOKER can't be specified for MATERIALIZED VIEW. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageMaterializedView.cpp:102: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000192aac49 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::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000192b573e 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:733: 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&) @ 0x00000000192b4351 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 @ 0x00000000191ba866 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:53.903027 [ 2818 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:54.373647 [ 5779 ] {a10c35c9-47ef-4331-8245-8d059e01b773} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43102) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE TABLE test_9.test_mv_data (s String) ENGINE = MergeTree ORDER BY 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:54.375079 [ 5779 ] {a10c35c9-47ef-4331-8245-8d059e01b773} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199b6d85 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>) @ 0x0000000019e414a4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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>&&) @ 0x0000000019e407c2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b1e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:54.376199 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:54.529885 [ 2748 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:54.903660 [ 2731 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:55.221330 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:55.531057 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:55.904407 [ 2811 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:56.101488 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:56.531895 [ 3171 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:56.905224 [ 3036 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:56.948647 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:57.532964 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:57.782437 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:57.906240 [ 3148 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:58.099939 [ 4203 ] {895df2fd-4565-45ea-a5cb-9785a6ddaaac} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43276) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT count() FROM test_9.test_mv_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:58.100950 [ 4203 ] {895df2fd-4565-45ea-a5cb-9785a6ddaaac} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:58.533766 [ 3123 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:58.617432 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:58.706069 [ 4203 ] {15d63484-5e47-492a-872a-66343020d960} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43306) (comment: 02122_parallel_formatting_CSVWithNames.sh) (in query: select number, number + 1, concat('string: ', toString(number)) from numbers(200000) format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:58.706911 [ 4203 ] {15d63484-5e47-492a-872a-66343020d960} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:58.907180 [ 3098 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:59.466910 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:59.534648 [ 3087 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:04:59.757926 [ 3849 ] {767cf0f2-2c00-4ad7-9b3e-258e01bde3cb} executeQuery: Code: 60. DB::Exception: Table test_9.test_mv_data does not exist. Maybe you meant test_9.test_mv_1?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43334) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_9.test_mv_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:606: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000192ab74a 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:226: DB::StorageMaterializedView::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000192ab89f 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:424: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000017513dce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174abeca 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cc8c2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:59.759140 [ 3849 ] {767cf0f2-2c00-4ad7-9b3e-258e01bde3cb} TCPHandler: Code: 60. DB::Exception: Table test_9.test_mv_data does not exist. Maybe you meant test_9.test_mv_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:606: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000192ab74a 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:226: DB::StorageMaterializedView::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000192ab89f 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:424: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000017513dce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174abeca 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cc8c2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:04:59.908018 [ 3086 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:00.118118 [ 3849 ] {0b877ed0-0ff3-4e96-aa0c-3dcc2d1e52ce} PushingToViews: Failed to push block to view test_9.test_mv_4 (a543087f-02fc-4b06-94b7-7621048bf18c), Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table 2025.06.12 19:05:00.224641 [ 3849 ] {0b877ed0-0ff3-4e96-aa0c-3dcc2d1e52ce} executeQuery: Code: 60. DB::Exception: Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43348) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO test_9.test_table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a784c3b 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a786261 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d42c0f 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44e9c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:00.225649 [ 3849 ] {0b877ed0-0ff3-4e96-aa0c-3dcc2d1e52ce} TCPHandler: Code: 60. DB::Exception: Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a784c3b 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a786261 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d42c0f 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44e9c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:00.284227 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:00.535553 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:00.634104 [ 3849 ] {c289a19a-f4bc-4a86-8042-66ff90f1ffbe} PushingToViews: Failed to push block to view test_9.test_mv_4 (a543087f-02fc-4b06-94b7-7621048bf18c), Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table 2025.06.12 19:05:00.908749 [ 3062 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:01.123239 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:01.536398 [ 3054 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:01.789140 [ 3849 ] {5c226483-c49d-4ce1-91cf-2ceb200db43c} PushingToViews: Failed to push block to view test_9.test_mv_4 (a543087f-02fc-4b06-94b7-7621048bf18c), Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table 2025.06.12 19:05:01.790195 [ 3849 ] {5c226483-c49d-4ce1-91cf-2ceb200db43c} executeQuery: Code: 60. DB::Exception: Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43406) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO test_9.test_table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a784c3b 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a786261 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d42c0f 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44e9c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:01.791261 [ 3849 ] {5c226483-c49d-4ce1-91cf-2ceb200db43c} TCPHandler: Code: 60. DB::Exception: Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a784c3b 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a786261 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d42c0f 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44e9c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:01.909542 [ 3197 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:02.090840 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:02.248928 [ 3849 ] {6d158ad0-af64-41fb-a813-4de79da29e39} executeQuery: Code: 60. DB::Exception: Table test_9.test_mv_data does not exist. Maybe you meant test_9.test_mv_1?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39480) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT count() FROM test_9.test_mv_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:606: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000192ab74a 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:226: DB::StorageMaterializedView::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000192ab89f 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:424: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000017513dce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174abeca 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cc8c2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:02.250119 [ 3849 ] {6d158ad0-af64-41fb-a813-4de79da29e39} TCPHandler: Code: 60. DB::Exception: Table test_9.test_mv_data does not exist. Maybe you meant test_9.test_mv_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:606: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000192ab74a 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:226: DB::StorageMaterializedView::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000192ab89f 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:424: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000017513dce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174abeca 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cc8c2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:02.537092 [ 3020 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:02.910274 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:02.928137 [ 3849 ] {2115d133-61f8-43a3-9940-d57edcdc249d} executeQuery: Code: 60. DB::Exception: Table test_9.test_mv_data does not exist. Maybe you meant test_9.test_mv_1?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39516) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_9.test_mv_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:606: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000192ab74a 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:226: DB::StorageMaterializedView::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000192ab89f 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:424: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000017513dce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174abeca 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cc8c2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:02.928908 [ 3849 ] {2115d133-61f8-43a3-9940-d57edcdc249d} TCPHandler: Code: 60. DB::Exception: Table test_9.test_mv_data does not exist. Maybe you meant test_9.test_mv_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:606: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000192ab74a 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:226: DB::StorageMaterializedView::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000192ab89f 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:424: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000017513dce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1458: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174abeca 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cc8c2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:02.984234 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:03.299718 [ 3849 ] {c903e01c-9ded-4f9d-aa66-3b7299210a55} PushingToViews: Failed to push block to view test_9.test_mv_4 (a543087f-02fc-4b06-94b7-7621048bf18c), Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table 2025.06.12 19:05:03.300463 [ 3849 ] {c903e01c-9ded-4f9d-aa66-3b7299210a55} executeQuery: Code: 60. DB::Exception: Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39534) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO test_9.test_table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a784c3b 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a786261 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d42c0f 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44e9c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:03.301224 [ 3849 ] {c903e01c-9ded-4f9d-aa66-3b7299210a55} TCPHandler: Code: 60. DB::Exception: Target table 'test_9.test_mv_data' of view 'test_9.test_mv_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a784c3b 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a786261 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d42c0f 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44e9c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:03.537715 [ 3015 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:03.897275 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:03.910942 [ 2954 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:04.088881 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e9e0d59b-2aba-4b2f-ad8d-5eadcca2d545::202506_1_101_20}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:04.295421 [ 4203 ] {a1909db7-c167-4b80-9103-3a9720caaadb} executeQuery: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(a) ON test_9.source. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39562) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO source SELECT * FROM generateRandom() LIMIT 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44adb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:04.296438 [ 4203 ] {a1909db7-c167-4b80-9103-3a9720caaadb} TCPHandler: Code: 497. DB::Exception: user02884_2_test_9_8540: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(a) ON test_9.source. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001671e5c0 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000001671e18e 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000001671d574 7. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x00000000166f94b5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000175a3198 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44adb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:04.538379 [ 2874 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:04.742163 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:04.911804 [ 2846 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:05.329395 [ 2836 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001769e9e7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000001769f17c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176aa3a2 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:05.336874 [ 4083 ] {112bc313-c760-4b9b-8f84-241e4a543532} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43656) (comment: 02967_parallel_replicas_joins_and_analyzer.gen.sql) (in query: DROP DATABASE IF EXISTS test_dcrfcamu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:05.337821 [ 4083 ] {112bc313-c760-4b9b-8f84-241e4a543532} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:05.345944 [ 4203 ] {93d1075e-14bc-4f6c-9742-389d9195d566} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58414) (comment: 02967_parallel_replicas_joins_and_analyzer.gen.sql) (in query: DROP DATABASE IF EXISTS test_dcrfcamu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:05.346891 [ 4203 ] {93d1075e-14bc-4f6c-9742-389d9195d566} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:05.539134 [ 3030 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:05.615663 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:05.912613 [ 2806 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:06.023524 [ 4203 ] {2ff14a1e-6b35-4765-b2d9-b3511df44474} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39598) (comment: 00143_number_classification_functions.sql) (in query: select isFinite(-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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:06.024096 [ 4203 ] {2ff14a1e-6b35-4765-b2d9-b3511df44474} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:06.429592 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:06.514748 [ 4203 ] {d45d962b-7faa-4f5a-893d-852c2436a84b} executeQuery: Code: 48. DB::Exception: ALTER MODIFY SQL SECURITY is not supported by MergeTree engines family. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39624) (comment: 02884_create_view_with_sql_security_option.sh) (in query: ALTER TABLE test_table MODIFY SQL SECURITY INVOKER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199df878 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:06.516138 [ 4203 ] {d45d962b-7faa-4f5a-893d-852c2436a84b} TCPHandler: Code: 48. DB::Exception: ALTER MODIFY SQL SECURITY is not supported by MergeTree engines family. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199df878 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:06.539953 [ 2763 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:06.913203 [ 2776 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:07.259542 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:07.540770 [ 2757 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:07.913966 [ 2729 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:08.078679 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:08.181294 [ 5779 ] {4057a42b-aa10-4376-a26a-5862672b012d} executeQuery: Code: 497. DB::Exception: user02884_1_test_9_15779: Not enough privileges. To execute this query, it's necessary to have the grant SET DEFINER ON user02884_2_test_9_8540. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39698) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE VIEW test_9.test_view_g_2 DEFINER = user02884_2_test_9_8540 AS SELECT * FROM test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016715b70 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000167157a1 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016714c07 7. ./build_docker/./src/Access/ContextAccess.cpp:824: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x00000000166f9124 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x00000000175a2429 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x0000000017c45fc0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c402e0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:08.182309 [ 5779 ] {4057a42b-aa10-4376-a26a-5862672b012d} TCPHandler: Code: 497. DB::Exception: user02884_1_test_9_15779: Not enough privileges. To execute this query, it's necessary to have the grant SET DEFINER ON user02884_2_test_9_8540. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016715b70 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000167157a1 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016714c07 7. ./build_docker/./src/Access/ContextAccess.cpp:824: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x00000000166f9124 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x00000000175a2429 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x0000000017c45fc0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c402e0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:08.541776 [ 2698 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:08.913073 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:08.914850 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:09.495872 [ 4203 ] {0fe0aad6-a132-4250-90a2-d095322ee308} executeQuery: Code: 497. DB::Exception: user02884_1_test_9_15779: Not enough privileges. To execute this query, it's necessary to have the grant ALLOW SQL SECURITY NONE ON *.*. (ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39746) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE VIEW test_9.test_view_g_3 SQL SECURITY NONE AS SELECT * FROM test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016713a98 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000167136c0 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000016712b6a 7. ./build_docker/./src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x00000000166f905a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x00000000175a2337 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x0000000017c46044 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c402e0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:09.497016 [ 4203 ] {0fe0aad6-a132-4250-90a2-d095322ee308} TCPHandler: Code: 497. DB::Exception: user02884_1_test_9_15779: Not enough privileges. To execute this query, it's necessary to have the grant ALLOW SQL SECURITY NONE ON *.*. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016713a98 5. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000167136c0 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000016712b6a 7. ./build_docker/./src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x00000000166f905a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x00000000175a2337 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x0000000017c46044 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c402e0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:09.542762 [ 3160 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:09.780209 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:09.915572 [ 3148 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:10.544049 [ 3120 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:10.620982 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:10.916381 [ 3100 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:11.466363 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:11.544758 [ 3086 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:11.645581 [ 4203 ] {1aaa9f23-62ef-4e49-9605-016c4d13bf5e} executeQuery: Code: 57. DB::Exception: Table test_15.test2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39850) (comment: 01009_global_array_join_names.sql) (in query: CREATE TABLE test2 as test1 ENGINE Distributed(test_shard_localhost, currentDatabase(), test1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:11.646801 [ 4203 ] {1aaa9f23-62ef-4e49-9605-016c4d13bf5e} TCPHandler: Code: 57. DB::Exception: Table test_15.test2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:11.917025 [ 3073 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:12.300309 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:12.545441 [ 3054 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:12.917650 [ 3034 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:13.038383 [ 4083 ] {bc77912a-6d94-4b3c-b735-83de14dba389} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57378) (comment: 02575_merge_prewhere_materialized.sql) (in query: -- Allow PREWHERE when Merge has DEFAULT and MergeTree has MATERIALIZED DROP TABLE IF EXISTS m;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:13.039612 [ 4083 ] {bc77912a-6d94-4b3c-b735-83de14dba389} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1b2d1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6bd8a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:13.138940 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:13.546075 [ 2997 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:13.918659 [ 2982 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:13.974045 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:14.547041 [ 2950 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:14.896617 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:14.919306 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:15.547912 [ 2907 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:15.828817 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:15.835737 [ 4203 ] {b6dca0c9-4aea-4838-a705-e340ff61a6fe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57422) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:15.837723 [ 4203 ] {b6dca0c9-4aea-4838-a705-e340ff61a6fe} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:15.920022 [ 2886 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:16.267844 [ 3849 ] {1b3cff23-a333-4ed4-ab47-06fc49b9368d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=774). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57430) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:16.268672 [ 3849 ] {1b3cff23-a333-4ed4-ab47-06fc49b9368d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=774). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:16.548581 [ 2873 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:16.660205 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:16.920887 [ 2836 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:17.381612 [ 4203 ] {91d38879-647c-4e26-b932-77f37b7f2465} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57578) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.382879 [ 4203 ] {91d38879-647c-4e26-b932-77f37b7f2465} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.481946 [ 4083 ] {6f6d295b-c8fe-4134-a0ff-dfe54a932bab} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57620) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_pk RENAME COLUMN key1 TO renamed_key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.489563 [ 4083 ] {6f6d295b-c8fe-4134-a0ff-dfe54a932bab} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key1 column which is a part of key expression. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.499748 [ 4083 ] {8ba85130-6863-4309-a2da-4b898489e2f5} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key3 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57620) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_pk RENAME COLUMN key3 TO renamed_key3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.500164 [ 4083 ] {8ba85130-6863-4309-a2da-4b898489e2f5} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key3 column which is a part of key expression. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.502724 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.509584 [ 4083 ] {94991f79-f103-49aa-8cae-028c6849fd4f} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57620) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_pk RENAME COLUMN key2 TO renamed_key2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.510027 [ 4083 ] {94991f79-f103-49aa-8cae-028c6849fd4f} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key2 column which is a part of key expression. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.549325 [ 2782 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:17.921590 [ 3182 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:17.977937 [ 3849 ] {16210359-0e45-4532-90a4-09f60b4cfb17} 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.10057.altinitytest (altinity build)) (from [::1]:57606) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:17.979107 [ 3849 ] {16210359-0e45-4532-90a4-09f60b4cfb17} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.229190 [ 4083 ] {5bb0b453-d485-44ab-94bf-e6b2486aff1d} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57620) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_with_primary_key RENAME COLUMN key1 TO renamed_key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.229662 [ 4083 ] {5bb0b453-d485-44ab-94bf-e6b2486aff1d} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key1 column which is a part of key expression. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.239940 [ 4083 ] {db5aa0e7-4a60-49a7-8d1e-fa9d79e29dea} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57620) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_with_primary_key RENAME COLUMN key2 TO renamed_key2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.240728 [ 4083 ] {db5aa0e7-4a60-49a7-8d1e-fa9d79e29dea} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key2 column which is a part of key expression. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.250830 [ 4083 ] {cc4b0d07-aca4-4008-874a-6bb1dc69ca9a} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key3 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57620) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_with_primary_key RENAME COLUMN key3 TO renamed_key3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.251274 [ 4083 ] {cc4b0d07-aca4-4008-874a-6bb1dc69ca9a} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key3 column which is a part of key expression. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e00a2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2077b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.375008 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.550140 [ 3021 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:18.922141 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:18.922383 [ 4203 ] {ebb51f66-5daf-437d-8025-48f69441c4b2} 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.10057.altinitytest (altinity build)) (from [::1]:57752) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:18.923900 [ 4203 ] {ebb51f66-5daf-437d-8025-48f69441c4b2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:19.361538 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:19.551222 [ 2962 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:19.922968 [ 2944 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:20.222936 [ 20807 ] {58f46f14-2258-46da-8a88-722ea86393e0} 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.10057.altinitytest (altinity build)) (from [::1]:57702) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:20.224312 [ 20807 ] {58f46f14-2258-46da-8a88-722ea86393e0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:20.323050 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:20.339479 [ 5779 ] {0bea9e81-1483-4d0f-ac67-c7b9b9220435} 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.10057.altinitytest (altinity build)) (from [::1]:57842) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:20.341041 [ 5779 ] {0bea9e81-1483-4d0f-ac67-c7b9b9220435} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:20.552013 [ 3196 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:20.923710 [ 2903 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:21.146271 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:21.552905 [ 2879 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:21.924476 [ 2880 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:22.047618 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:22.069986 [ 5779 ] {45300bf5-81a9-4276-bc32-653d9e04d029} 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.10057.altinitytest (altinity build)) (from [::1]:58004) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:22.076770 [ 5779 ] {45300bf5-81a9-4276-bc32-653d9e04d029} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:22.393892 [ 4203 ] {f7270ac5-5275-4728-b480-bfc7b0b0384c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57974) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:22.395505 [ 4203 ] {f7270ac5-5275-4728-b480-bfc7b0b0384c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:22.553637 [ 2859 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:22.877560 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:22.925433 [ 2875 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:22.978964 [ 3849 ] {2e022a2d-c677-4817-955a-f5b89c179ff9} 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.10057.altinitytest (altinity build)) (from [::1]:46064) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:22.980507 [ 3849 ] {2e022a2d-c677-4817-955a-f5b89c179ff9} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:23.372807 [ 5779 ] {3854fb98-85af-4466-916d-23e3b7ed25f4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46100) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:23.374105 [ 5779 ] {3854fb98-85af-4466-916d-23e3b7ed25f4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:23.554393 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:23.807266 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:23.873730 [ 4203 ] {7926e3cf-e805-4bda-a20e-b7964c0c9d15} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46160). (NETWORK_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46160) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000001a1ed1a3 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e6608 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:23.926271 [ 2797 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:23.944899 [ 4203 ] {7926e3cf-e805-4bda-a20e-b7964c0c9d15} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46160). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f84e7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e7adc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9339 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:23.962051 [ 4203 ] {7926e3cf-e805-4bda-a20e-b7964c0c9d15} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46160). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000001a1ed1a3 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e6608 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:23.962897 [ 4203 ] {7926e3cf-e805-4bda-a20e-b7964c0c9d15} TCPHandler: Client has gone away. 2025.06.12 19:05:24.555412 [ 2783 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:24.630350 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:24.962384 [ 2809 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:24.980388 [ 3849 ] {256caf45-c76d-44e9-8cdd-e53331a988c9} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to arrayEnumerateDense must be equal.: while executing 'FUNCTION arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String) :: 1, array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String))) :: 2) -> arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String), array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)))) Array(UInt32) : 0'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46232) (comment: 00808_array_enumerate_segfault.sql) (in query: SELECT arrayEnumerateDense([], [sequenceCount(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::FunctionArrayEnumerateExtended::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f34a7a2 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:24.981270 [ 3849 ] {256caf45-c76d-44e9-8cdd-e53331a988c9} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to arrayEnumerateDense must be equal.: while executing 'FUNCTION arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String) :: 1, array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String))) :: 2) -> arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String), array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)))) Array(UInt32) : 0'. (SIZES_OF_ARRAYS_DONT_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::FunctionArrayEnumerateExtended::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f34a7a2 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:25.466435 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:25.556214 [ 2739 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:25.963054 [ 2723 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:26.376027 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:26.557068 [ 2710 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:26.963766 [ 2694 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:27.268846 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:27.443937 [ 4083 ] {264d9f4b-7be1-4b34-9fa1-3e87e0864c4b} executeQuery: Code: 69. DB::Exception: A call to function range would produce 12 array elements, which is greater than the allowed maximum of 10: while executing 'FUNCTION range(modulo(__table1.number, 3_UInt8) :: 0) -> range(modulo(__table1.number, 3_UInt8)) Array(UInt8) : 1'. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46366) (comment: 01944_range_max_elements.sql) (in query: SELECT range(number % 3) FROM numbers(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x000000000f96671e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961a37 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:27.444606 [ 4083 ] {264d9f4b-7be1-4b34-9fa1-3e87e0864c4b} TCPHandler: Code: 69. DB::Exception: A call to function range would produce 12 array elements, which is greater than the allowed maximum of 10: while executing 'FUNCTION range(modulo(__table1.number, 3_UInt8) :: 0) -> range(modulo(__table1.number, 3_UInt8)) Array(UInt8) : 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000077188ac 4. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x000000000f96671e 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f961a37 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:27.557919 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:27.964581 [ 3174 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:28.123682 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.558968 [ 3139 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:28.822259 [ 4083 ] {842c8cce-a8e6-4c48-b688-9bec3c316ec5} executeQuery: Code: 184. DB::Exception: Aggregate function avg(number) AS number is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46474) (comment: 01764_prefer_column_name_to_alias.sql) (in query: SELECT avg(number) AS number, max(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x0000000009572ec6 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f3dc 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f358 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000001750f710 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001750a1f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493069 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.871311 [ 4083 ] {842c8cce-a8e6-4c48-b688-9bec3c316ec5} TCPHandler: Code: 184. DB::Exception: Aggregate function avg(number) AS number is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x0000000009572ec6 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f3dc 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f358 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000001750f710 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001750a1f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493069 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.883832 [ 3966 ] {43d3eaee-ba95-47bb-af7e-b07acb906122} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57162) (comment: 02025_subcolumns_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_0gzn9hh3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.884864 [ 3966 ] {43d3eaee-ba95-47bb-af7e-b07acb906122} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:28.892628 [ 3849 ] {dcb45846-04ed-4074-bd17-bd861c87bb17} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57178) (comment: 02025_subcolumns_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_0gzn9hh3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.893415 [ 3849 ] {dcb45846-04ed-4074-bd17-bd861c87bb17} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:28.930861 [ 4083 ] {0a5b4ed1-ef24-4c87-897f-fd7b67503be5} executeQuery: Code: 184. DB::Exception: Aggregate function sum(x) AS x is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46474) (comment: 01764_prefer_column_name_to_alias.sql) (in query: SELECT sum(x) AS x, max(x) FROM (SELECT 1 AS x UNION ALL SELECT 2 AS x) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x0000000009572ec6 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f3dc 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f358 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000001750f710 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001750a1f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493069 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.931587 [ 4083 ] {0a5b4ed1-ef24-4c87-897f-fd7b67503be5} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(x) AS x is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x0000000009572ec6 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f3dc 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f358 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000001750f710 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001750a1f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493069 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.940820 [ 4083 ] {fe8f8a71-01dc-4eb9-9445-2edf81894e92} executeQuery: Code: 184. DB::Exception: Aggregate function sum(C1) AS C1 is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46474) (comment: 01764_prefer_column_name_to_alias.sql) (in query: select sum(C1) as C1, count(C1) as C2 from (select number as C1 from numbers(3)) as ITBL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x0000000009572ec6 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f3dc 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f358 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000001750f710 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001750a1f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493069 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.941451 [ 4083 ] {fe8f8a71-01dc-4eb9-9445-2edf81894e92} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(C1) AS C1 is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x0000000009572ec6 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f3dc 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001750f358 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000001750f710 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001750a1f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017493069 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.953176 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:28.965202 [ 3124 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:29.559607 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:29.804594 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:29.965984 [ 3112 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:30.560438 [ 3084 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:30.657321 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:30.966800 [ 3069 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:31.484057 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:31.561478 [ 3051 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:31.967672 [ 3026 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:31.998719 [ 20807 ] {3d792a27-1e63-4311-82ac-4687543b5668} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 76.29 MiB (attempt to allocate chunk of 80000512 bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46608) (comment: 01109_inflating_cross_join.sql) (in query: SELECT count(*) FROM numbers(10000) n1 CROSS JOIN numbers(1000) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000f9bd8e0 8. ./src/Common/PODArray.h:0: DB::ColumnVector::reserve(unsigned long) @ 0x0000000018e418a9 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x000000001836261d 10. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:913: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x00000000183658b5 11. ./contrib/llvm-project/libcxx/include/string:1570: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001a69bb94 12. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000001a8f29b7 13. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000001a8f445e 14. ./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) @ 0x000000001a8f1703 15. ./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&) @ 0x0000000017df0801 16. ./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&) @ 0x0000000017de0b12 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:31.999289 [ 20807 ] {3d792a27-1e63-4311-82ac-4687543b5668} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 76.29 MiB (attempt to allocate chunk of 80000512 bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa33625 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa324de 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3207e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9bfa0f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000f9bd8e0 8. ./src/Common/PODArray.h:0: DB::ColumnVector::reserve(unsigned long) @ 0x0000000018e418a9 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x000000001836261d 10. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:913: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x00000000183658b5 11. ./contrib/llvm-project/libcxx/include/string:1570: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001a69bb94 12. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000001a8f29b7 13. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000001a8f445e 14. ./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) @ 0x000000001a8f1703 15. ./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&) @ 0x0000000017df0801 16. ./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&) @ 0x0000000017de0b12 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:32.020148 [ 20807 ] {00b8fccc-676b-46c7-bd5c-9e250744bd8d} 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.10057.altinitytest (altinity build)) (from [::1]:46608) (comment: 01109_inflating_cross_join.sql) (in query: SELECT count(*) FROM numbers(10000) n1 CROSS JOIN numbers(1000) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:32.021580 [ 20807 ] {00b8fccc-676b-46c7-bd5c-9e250744bd8d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:32.303836 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:32.422714 [ 20807 ] {b097ad07-b745-46cf-bb65-57c917b909aa} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36474) (comment: 01442_merge_detach_attach_long.sh) (in query: OPTIMIZE TABLE t 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e5400b 5. ./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) @ 0x0000000019e5ab6b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:32.423308 [ 20807 ] {b097ad07-b745-46cf-bb65-57c917b909aa} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e5400b 5. ./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) @ 0x0000000019e5ab6b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:32.562237 [ 3008 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:32.968345 [ 3007 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:33.127235 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:33.562961 [ 2973 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:33.746254 [ 3849 ] {630dc104-e2ac-4189-9902-1ffe111f9a38} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36494) (comment: 02154_bit_slice_for_string.sql) (in query: select null as offset, null as s, subString(bin(s), offset), bin(bitSlice(s, offset));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:33.746989 [ 3849 ] {630dc104-e2ac-4189-9902-1ffe111f9a38} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:33.957155 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:33.969006 [ 2961 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:34.563853 [ 2941 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:34.855054 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:34.969702 [ 2933 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:35.564559 [ 2914 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:35.696802 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:35.739906 [ 3849 ] {b19144aa-73fe-411c-9c85-b4c5b35f569c} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36626) (comment: 01442_merge_detach_attach_long.sh) (in query: OPTIMIZE TABLE t 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e5400b 5. ./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) @ 0x0000000019e5ab6b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:35.740399 [ 3849 ] {b19144aa-73fe-411c-9c85-b4c5b35f569c} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e5400b 5. ./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) @ 0x0000000019e5ab6b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:35.970362 [ 2907 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:36.532175 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:36.565199 [ 3145 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:36.971255 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:37.256777 [ 12426 ] {} BackupsWorker: Failed to make internal backup Disk('backups', '02907_backup_mv_with_no_source_table_test_9'): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000168749b4 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:0: DB::BackupEntriesCollector::run() @ 0x000000001686fe30 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b940d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x00000000168c49fe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:37.376523 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:37.461167 [ 3849 ] {2e306299-10d1-45eb-8aad-eb72c45c5df0} BackupsWorker: Failed to make backup Disk('backups', '02907_backup_mv_with_no_source_table_test_9'): Code: 439. DB::Exception: Got error from localhost:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000168749b4 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:0: DB::BackupEntriesCollector::run() @ 0x000000001686fe30 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b940d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x00000000168c49fe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 . (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:0: DB::BackupCoordinationStageSync::readCurrentState(DB::WithRetries::RetriesControlHolder&, std::vector> const&, std::vector> const&, String const&) const @ 0x00000000168f7047 4. ./contrib/llvm-project/libcxx/include/optional:393: DB::BackupCoordinationStageSync::waitImpl(std::vector> const&, String const&, std::optional>>) const @ 0x00000000168f3c3a 5. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:93: DB::BackupCoordinationStageSync::wait(std::vector> const&, String const&) @ 0x00000000168f3457 6. ./build_docker/./src/Backups/BackupCoordinationRemote.cpp:280: DB::BackupCoordinationRemote::waitForStage(String const&) @ 0x00000000168cf818 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9bd2 8. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b4bde 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41fa 10. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:37.566088 [ 2843 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:37.569092 [ 3849 ] {2e306299-10d1-45eb-8aad-eb72c45c5df0} executeQuery: Code: 439. DB::Exception: Got error from localhost:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000168749b4 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:0: DB::BackupEntriesCollector::run() @ 0x000000001686fe30 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b940d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x00000000168c49fe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 . (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36668) (comment: 02907_backup_mv_with_no_source_table.sh) (in query: backup database test_9 on cluster test_shard_localhost to Disk('backups', '02907_backup_mv_with_no_source_table_test_9');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:0: DB::BackupCoordinationStageSync::readCurrentState(DB::WithRetries::RetriesControlHolder&, std::vector> const&, std::vector> const&, String const&) const @ 0x00000000168f7047 4. ./contrib/llvm-project/libcxx/include/optional:393: DB::BackupCoordinationStageSync::waitImpl(std::vector> const&, String const&, std::optional>>) const @ 0x00000000168f3c3a 5. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:93: DB::BackupCoordinationStageSync::wait(std::vector> const&, String const&) @ 0x00000000168f3457 6. ./build_docker/./src/Backups/BackupCoordinationRemote.cpp:280: DB::BackupCoordinationRemote::waitForStage(String const&) @ 0x00000000168cf818 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9bd2 8. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b4bde 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41fa 10. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:37.570300 [ 3849 ] {2e306299-10d1-45eb-8aad-eb72c45c5df0} TCPHandler: Code: 439. DB::Exception: Got error from localhost:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000168749b4 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:0: DB::BackupEntriesCollector::run() @ 0x000000001686fe30 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b940d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x00000000168c49fe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 . (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:0: DB::BackupCoordinationStageSync::readCurrentState(DB::WithRetries::RetriesControlHolder&, std::vector> const&, std::vector> const&, String const&) const @ 0x00000000168f7047 4. ./contrib/llvm-project/libcxx/include/optional:393: DB::BackupCoordinationStageSync::waitImpl(std::vector> const&, String const&, std::optional>>) const @ 0x00000000168f3c3a 5. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:93: DB::BackupCoordinationStageSync::wait(std::vector> const&, String const&) @ 0x00000000168f3457 6. ./build_docker/./src/Backups/BackupCoordinationRemote.cpp:280: DB::BackupCoordinationRemote::waitForStage(String const&) @ 0x00000000168cf818 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9bd2 8. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b4bde 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41fa 10. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:37.972018 [ 2844 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:38.037137 [ 3849 ] {1b519927-504f-46a4-8790-0deaf086cf93} BackupsWorker: Failed to restore from backup Disk('backups', '02907_backup_mv_with_no_source_table_test_9'): Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_9') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000016979863 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016974cb8 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x000000001697406c 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699f3b4 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000016916ced 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168bec25 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b6320 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41b0 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:38.037998 [ 3849 ] {1b519927-504f-46a4-8790-0deaf086cf93} executeQuery: Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_9') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36740) (comment: 02907_backup_mv_with_no_source_table.sh) (in query: restore table test_9.mv on cluster test_shard_localhost from Disk('backups', '02907_backup_mv_with_no_source_table_test_9');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000016979863 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016974cb8 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x000000001697406c 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699f3b4 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000016916ced 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168bec25 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b6320 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41b0 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:38.038945 [ 3849 ] {1b519927-504f-46a4-8790-0deaf086cf93} TCPHandler: Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_9') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000016979863 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016974cb8 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x000000001697406c 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699f3b4 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000016916ced 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168bec25 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b6320 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41b0 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:38.208605 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:38.540470 [ 3849 ] {e80c467a-468e-4a33-a550-1d0a1cf61966} executeQuery: Code: 57. DB::Exception: Table test_9.mv already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36780) (comment: 02907_backup_mv_with_no_source_table.sh) (in query: create materialized view mv to dst (a Int32) as select * from src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:38.541208 [ 3849 ] {e80c467a-468e-4a33-a550-1d0a1cf61966} TCPHandler: Code: 57. DB::Exception: Table test_9.mv already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:38.567173 [ 2816 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:38.972844 [ 2786 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:39.093044 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:39.545370 [ 17152 ] {} BackupsWorker: Failed to make internal backup Disk('backups', '02907_backup_mv_with_no_source_table_test_92'): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000168749b4 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:0: DB::BackupEntriesCollector::run() @ 0x000000001686fe30 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b940d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x00000000168c49fe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:39.551214 [ 3849 ] {284df39a-2abd-4290-ae72-946dc6d40f7d} BackupsWorker: Failed to make backup Disk('backups', '02907_backup_mv_with_no_source_table_test_92'): Code: 439. DB::Exception: Got error from localhost:9000. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000168749b4 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:0: DB::BackupEntriesCollector::run() @ 0x000000001686fe30 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b940d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x00000000168c49fe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 . (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:0: DB::BackupCoordinationStageSync::readCurrentState(DB::WithRetries::RetriesControlHolder&, std::vector> const&, std::vector> const&, String const&) const @ 0x00000000168f7047 4. ./contrib/llvm-project/libcxx/include/optional:393: DB::BackupCoordinationStageSync::waitImpl(std::vector> const&, String const&, std::optional>>) const @ 0x00000000168f3c3a 5. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:93: DB::BackupCoordinationStageSync::wait(std::vector> const&, String const&) @ 0x00000000168f3457 6. ./build_docker/./src/Backups/BackupCoordinationRemote.cpp:280: DB::BackupCoordinationRemote::waitForStage(String const&) @ 0x00000000168cf818 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9bd2 8. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b4bde 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41fa 10. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:39.567920 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:39.690980 [ 3849 ] {284df39a-2abd-4290-ae72-946dc6d40f7d} executeQuery: Code: 439. DB::Exception: Got error from localhost:9000. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000168749b4 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:0: DB::BackupEntriesCollector::run() @ 0x000000001686fe30 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b940d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x00000000168c49fe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 . (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36804) (comment: 02907_backup_mv_with_no_source_table.sh) (in query: backup database test_9 on cluster test_shard_localhost to Disk('backups', '02907_backup_mv_with_no_source_table_test_92');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:0: DB::BackupCoordinationStageSync::readCurrentState(DB::WithRetries::RetriesControlHolder&, std::vector> const&, std::vector> const&, String const&) const @ 0x00000000168f7047 4. ./contrib/llvm-project/libcxx/include/optional:393: DB::BackupCoordinationStageSync::waitImpl(std::vector> const&, String const&, std::optional>>) const @ 0x00000000168f3c3a 5. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:93: DB::BackupCoordinationStageSync::wait(std::vector> const&, String const&) @ 0x00000000168f3457 6. ./build_docker/./src/Backups/BackupCoordinationRemote.cpp:280: DB::BackupCoordinationRemote::waitForStage(String const&) @ 0x00000000168cf818 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9bd2 8. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b4bde 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41fa 10. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:39.692286 [ 3849 ] {284df39a-2abd-4290-ae72-946dc6d40f7d} TCPHandler: Code: 439. DB::Exception: Got error from localhost:9000. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000168749b4 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:0: DB::BackupEntriesCollector::run() @ 0x000000001686fe30 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b940d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x00000000168c49fe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 . (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:0: DB::BackupCoordinationStageSync::readCurrentState(DB::WithRetries::RetriesControlHolder&, std::vector> const&, std::vector> const&, String const&) const @ 0x00000000168f7047 4. ./contrib/llvm-project/libcxx/include/optional:393: DB::BackupCoordinationStageSync::waitImpl(std::vector> const&, String const&, std::optional>>) const @ 0x00000000168f3c3a 5. ./build_docker/./src/Backups/BackupCoordinationStageSync.cpp:93: DB::BackupCoordinationStageSync::wait(std::vector> const&, String const&) @ 0x00000000168f3457 6. ./build_docker/./src/Backups/BackupCoordinationRemote.cpp:280: DB::BackupCoordinationRemote::waitForStage(String const&) @ 0x00000000168cf818 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9bd2 8. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b4bde 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41fa 10. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:39.973450 [ 2783 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:39.977575 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:40.198043 [ 3849 ] {6f108202-ef8a-4a1f-a439-4f25ec056d0b} BackupsWorker: Failed to restore from backup Disk('backups', '02907_backup_mv_with_no_source_table_test_92'): Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_92') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000016979863 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016974cb8 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x000000001697406c 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699f3b4 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000016916ced 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168bec25 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b6320 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41b0 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:40.198948 [ 3849 ] {6f108202-ef8a-4a1f-a439-4f25ec056d0b} executeQuery: Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_92') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36886) (comment: 02907_backup_mv_with_no_source_table.sh) (in query: restore table test_9.mv on cluster test_shard_localhost from Disk('backups', '02907_backup_mv_with_no_source_table_test_92');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000016979863 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016974cb8 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x000000001697406c 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699f3b4 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000016916ced 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168bec25 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b6320 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41b0 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:40.199848 [ 3849 ] {6f108202-ef8a-4a1f-a439-4f25ec056d0b} TCPHandler: Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_92') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000016979863 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016974cb8 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x000000001697406c 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699f3b4 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x0000000016916ced 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168bec25 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b6320 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b41b0 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182b9365 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:40.568572 [ 2744 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:40.806055 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:40.974254 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:41.569633 [ 2731 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:41.665475 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:41.975221 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:42.206527 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c86f717d-83e3-4b01-97b8-8250998cbdff::202506_1_103_21}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:42.520257 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:42.571120 [ 2697 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:42.976725 [ 2684 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:43.371048 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:43.572135 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:43.977667 [ 3140 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:44.288122 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:44.573588 [ 3108 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:44.978900 [ 3111 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:45.161633 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:45.575022 [ 3080 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:45.979564 [ 3081 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:45.995291 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:46.575791 [ 3057 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:46.873793 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:46.980286 [ 3041 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:47.185266 [ 20807 ] {ff5d820b-d5d1-4aba-82dc-dddd52a18615} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45194) (comment: 01442_merge_detach_attach_long.sh) (in query: OPTIMIZE TABLE t 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e5400b 5. ./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) @ 0x0000000019e5ab6b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:47.185790 [ 20807 ] {ff5d820b-d5d1-4aba-82dc-dddd52a18615} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1149: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e5400b 5. ./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) @ 0x0000000019e5ab6b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:47.576628 [ 3019 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:47.706462 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:47.981044 [ 3007 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:48.577383 [ 2992 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:48.581130 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:48.657219 [ 5779 ] {} DynamicQueryHandler: Code: 372. DB::Exception: Session test_15_10 not found. (SESSION_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Interpreters/Session.cpp:116: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x0000000017f12126 5. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x0000000017f0e817 6. ./build_docker/./src/Server/HTTPHandler.cpp:220: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a12b24f 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:48.981888 [ 2983 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:49.153527 [ 4083 ] {92eb631d-a35b-40a7-8c47-96231e0733ab} executeQuery: Code: 650. DB::Exception: Serialization error: Transaction (134, 34, 087e8b3f-db6b-465f-8128-7340e808ee2a) tried to remove data part all_21_21_0 from test_xdvreyy3.t (fd873ae5-35cf-4b0f-8d42-84f80c4ccc37), but it's locked by another transaction (TID: (134, 33, 087e8b3f-db6b-465f-8128-7340e808ee2a), TIDH: 7807791637921129553) which is currently removing this part. (SERIALIZATION_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45278) (comment: 01442_merge_detach_attach_long.sh) (in query: ALTER TABLE t DETACH PARTITION tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::TransactionID const&, String&, String&&, DB::TransactionID&&, unsigned long&) @ 0x000000001812043c 4. ./build_docker/./src/Interpreters/TransactionVersionMetadata.cpp:0: DB::VersionMetadata::lockRemovalTID(DB::TransactionID const&, DB::TransactionInfoContext const&) @ 0x000000001811c99b 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::TransactionInfoContext const&) @ 0x0000000017e956de 6. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:93: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::MergeTreeTransaction*) @ 0x0000000017e9553b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::removePartsFromWorkingSet(DB::MergeTreeTransaction*, std::vector, std::allocator>> const&, bool, DB::DataPartsLock&) @ 0x00000000199ef4b2 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::dropPartition(std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000019e68e5a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000019a093fa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20d49 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:49.154134 [ 4083 ] {92eb631d-a35b-40a7-8c47-96231e0733ab} TCPHandler: Code: 650. DB::Exception: Serialization error: Transaction (134, 34, 087e8b3f-db6b-465f-8128-7340e808ee2a) tried to remove data part all_21_21_0 from test_xdvreyy3.t (fd873ae5-35cf-4b0f-8d42-84f80c4ccc37), but it's locked by another transaction (TID: (134, 33, 087e8b3f-db6b-465f-8128-7340e808ee2a), TIDH: 7807791637921129553) which is currently removing this part. (SERIALIZATION_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::TransactionID const&, String&, String&&, DB::TransactionID&&, unsigned long&) @ 0x000000001812043c 4. ./build_docker/./src/Interpreters/TransactionVersionMetadata.cpp:0: DB::VersionMetadata::lockRemovalTID(DB::TransactionID const&, DB::TransactionInfoContext const&) @ 0x000000001811c99b 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::TransactionInfoContext const&) @ 0x0000000017e956de 6. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:93: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::MergeTreeTransaction*) @ 0x0000000017e9553b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::removePartsFromWorkingSet(DB::MergeTreeTransaction*, std::vector, std::allocator>> const&, bool, DB::DataPartsLock&) @ 0x00000000199ef4b2 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::dropPartition(std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000019e68e5a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000019a093fa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20d49 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:49.505597 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:49.578238 [ 2972 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:49.759992 [ 4083 ] {9282d827-64ef-4ccf-8ab3-888813e57328} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45302) (comment: 01251_string_comparison.sql) (in query: SELECT isConstant('a' = '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:49.760756 [ 4083 ] {9282d827-64ef-4ccf-8ab3-888813e57328} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=769). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:49.982946 [ 2954 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:50.327618 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:50.579361 [ 2950 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:50.983671 [ 2984 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:51.208711 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:51.580133 [ 2914 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:51.984291 [ 2902 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:52.035356 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:52.580984 [ 2890 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:52.895104 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:52.985061 [ 2883 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:52.998910 [ 5779 ] {a5fcc894-3051-48f0-a657-dda301fbe536} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36834) (comment: 02669_alter_modify_to_nullable.sql) (in query: DROP DATABASE IF EXISTS test_ntvdyg1s ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:52.999938 [ 5779 ] {a5fcc894-3051-48f0-a657-dda301fbe536} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:53.584205 [ 2852 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:53.722157 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:53.812937 [ 3966 ] {cd6517a6-2f8f-458c-ba5e-8b13ad40ec55} 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.10057.altinitytest (altinity build)) (from [::1]:36462) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000017e440a9 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::InterpreterSelectQuery::initSettings() @ 0x0000000017d609ad 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) @ 0x0000000017d586cf 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) @ 0x0000000017d57c4c 12. ./contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017d578e6 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000017c7d950 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000017c7dd12 15. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000017c7dd1d 16. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000017c7dd1d 17. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000017c74e60 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000017c728df 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:53.813972 [ 3966 ] {cd6517a6-2f8f-458c-ba5e-8b13ad40ec55} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000017e440a9 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::InterpreterSelectQuery::initSettings() @ 0x0000000017d609ad 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) @ 0x0000000017d586cf 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) @ 0x0000000017d57c4c 12. ./contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017d578e6 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000017c7d950 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000017c7dd12 15. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000017c7dd1d 16. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000017c7dd1d 17. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000017c74e60 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000017c728df 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:53.985735 [ 2847 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:53.992337 [ 20807 ] {f2660db2-89aa-46d2-9642-af00acd2bf4b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36860) (comment: 03161_cnf_reduction.sql) (in query: DROP DATABASE IF EXISTS test_fw7po5sc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:53.993151 [ 20807 ] {f2660db2-89aa-46d2-9642-af00acd2bf4b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:53.999337 [ 3966 ] {93ea7b69-9daa-473a-8bf5-c5ddae9bb20f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36868) (comment: 03161_cnf_reduction.sql) (in query: DROP DATABASE IF EXISTS test_fw7po5sc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:54.000138 [ 3966 ] {93ea7b69-9daa-473a-8bf5-c5ddae9bb20f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:54.558107 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:54.585031 [ 2828 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:54.986268 [ 2785 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:55.099590 [ 3966 ] {92fe022c-5949-4a34-9cdf-4d71fd7a0fc5} executeQuery: Code: 36. DB::Exception: The maximum value for the input argument of function factorial is 20: In scope SELECT factorial(100). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36500) (comment: 02478_factorial.sql) (in query: select factorial(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000009e66424 5. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000009e66005 6. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000009e64d18 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009e641f9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:05:55.100177 [ 3966 ] {92fe022c-5949-4a34-9cdf-4d71fd7a0fc5} TCPHandler: Code: 36. DB::Exception: The maximum value for the input argument of function factorial is 20: In scope SELECT factorial(100). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000009e66424 5. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000009e66005 6. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000009e64d18 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009e641f9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:05:55.322433 [ 3966 ] {24288c21-161b-482b-9145-d564ef9aa02e} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function factorial: In scope SELECT factorial('100'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36500) (comment: 02478_factorial.sql) (in query: select factorial('100');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000009e6c0e8 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000009e64496 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:05:55.323033 [ 3966 ] {24288c21-161b-482b-9145-d564ef9aa02e} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function factorial: In scope SELECT factorial('100'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000009e6c0e8 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000009e64496 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 2025.06.12 19:05:55.350285 [ 4083 ] {4dd6d72a-cfbd-4656-b263-52d99097a3f5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36526) (comment: 01021_create_as_select.sql) (in query: CREATE TABLE create_as_select_01021 engine=Memory AS (SELECT (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:55.351569 [ 4083 ] {4dd6d72a-cfbd-4656-b263-52d99097a3f5} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:55.392000 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:55.467126 [ 3966 ] {0cf5b388-40af-4ef4-8da0-8e77699050f8} executeQuery: Code: 43. DB::Exception: Illegal type of argument of function factorial, should not be floating point or big int: In scope SELECT factorial(100.1234). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36500) (comment: 02478_factorial.sql) (in query: select factorial(100.1234);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000009e6b8fa 5. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000009e6b645 6. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000009e65ddc 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009e641f9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:05:55.477624 [ 3966 ] {0cf5b388-40af-4ef4-8da0-8e77699050f8} TCPHandler: Code: 43. DB::Exception: Illegal type of argument of function factorial, should not be floating point or big int: In scope SELECT factorial(100.1234). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000009e6b8fa 5. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000009e6b645 6. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000009e65ddc 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009e641f9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:05:55.585706 [ 2797 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:55.987295 [ 2767 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:56.031367 [ 3966 ] {7ae124b6-464d-4019-b677-f595196b0ade} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=785). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36544) (comment: 02113_format_row.sql) (in query: select formatRow('JSONCompactEachRowWithNamesAndTypes', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:56.031994 [ 3966 ] {7ae124b6-464d-4019-b677-f595196b0ade} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=785). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:56.227924 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:56.586428 [ 2760 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:56.672595 [ 20807 ] {855fe97f-225a-45f9-8593-1389a60d1cd7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=771). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36542) (comment: 00502_sum_map.sql) (in query: select sumMap(val, cnt) from ( SELECT [ CAST(1, 'UInt64') ] as val, [1] as cnt );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:56.673126 [ 20807 ] {855fe97f-225a-45f9-8593-1389a60d1cd7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=771). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:56.987932 [ 2801 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:57.053727 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:57.565870 [ 3966 ] {1ac8f0d7-71c3-46da-8144-a8369a285185} executeQuery: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '..', 2). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36572) (comment: 02798_substring_index.sql) (in query: select substringIndex('www.clickhouse.com', '..', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e295617 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:05:57.587302 [ 2770 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:57.594162 [ 3966 ] {1ac8f0d7-71c3-46da-8144-a8369a285185} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '..', 2). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e295617 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:05:57.700280 [ 3966 ] {f7ff06fd-cf2f-4986-b20c-ab3d4f45ffd8} executeQuery: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '', 2). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36572) (comment: 02798_substring_index.sql) (in query: select substringIndex('www.clickhouse.com', '', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e295617 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:05:57.700791 [ 3966 ] {f7ff06fd-cf2f-4986-b20c-ab3d4f45ffd8} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '', 2). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e295617 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:05:57.709277 [ 3966 ] {96e0f86a-68c4-4cf2-b1cc-9d642635feff} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function substringIndex must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36572) (comment: 02798_substring_index.sql) (in query: select substringIndex('www.clickhouse.com', materialize('.'), 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008710a94 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:57.709731 [ 3966 ] {96e0f86a-68c4-4cf2-b1cc-9d642635feff} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function substringIndex must be constant. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008710a94 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:57.875092 [ 3966 ] {930bce9d-4cd7-4666-a512-75d40a90848e} executeQuery: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndex, Integer expected: In scope SELECT substringIndex('www.clickhouse.com', '.', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36572) (comment: 02798_substring_index.sql) (in query: select substringIndex('www.clickhouse.com', '.', cast(2 as Int128));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e295efd 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:05:57.875705 [ 3966 ] {930bce9d-4cd7-4666-a512-75d40a90848e} TCPHandler: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndex, Integer expected: In scope SELECT substringIndex('www.clickhouse.com', '.', CAST(2, 'Int128')). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e295efd 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:05:57.891368 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:57.988643 [ 2750 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:58.587963 [ 2745 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:58.716863 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:58.990115 [ 2719 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:59.182763 [ 3966 ] {4128c008-4c94-4bd8-b58a-77faad3d5c72} executeQuery: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', ',,', 2). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36572) (comment: 02798_substring_index.sql) (in query: select substringIndexUTF8('富强,民主,文明', ',,', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e2986a6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:05:59.185047 [ 3966 ] {4128c008-4c94-4bd8-b58a-77faad3d5c72} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', ',,', 2). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e2986a6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:05:59.223078 [ 3966 ] {d58fbf8d-3f45-44ca-a6b5-05efb4b731d3} executeQuery: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', '', 2). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36572) (comment: 02798_substring_index.sql) (in query: select substringIndexUTF8('富强,民主,文明', '', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e2986a6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:05:59.223862 [ 3966 ] {d58fbf8d-3f45-44ca-a6b5-05efb4b731d3} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', '', 2). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e2986a6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:05:59.235026 [ 3966 ] {0460a734-fd9d-4aa0-b5ae-0af703ceb488} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function substringIndexUTF8 must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36572) (comment: 02798_substring_index.sql) (in query: select substringIndexUTF8('富强,民主,文明', materialize(','), 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008710a94 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:59.235552 [ 3966 ] {0460a734-fd9d-4aa0-b5ae-0af703ceb488} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function substringIndexUTF8 must be constant. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x0000000007b67086 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008710a94 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:59.452442 [ 4083 ] {30c69c56-0a35-4db6-8aff-3026a19e6d6b} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f4bd4931000, frame address: 0x7f4bd50bb370, stack size: 482448, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54196) (comment: 00984_parser_stack_overflow.sh) (in 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000000fa808d4 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000000fa80784 5. ./src/Parsers/TokenIterator.h:81: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af98154 6. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afe44a9 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 8. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af49321 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 10. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afffb52 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 12. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6e5a1 13. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 14. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afe44a9 15. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 16. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af49321 17. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 18. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afffb52 19. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 20. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6e5a1 21. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 22. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afe44a9 23. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 24. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af49321 25. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 26. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afffb52 27. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 28. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6e5a1 29. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 30. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afe44a9 31. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 2025.06.12 19:05:59.454154 [ 4083 ] {30c69c56-0a35-4db6-8aff-3026a19e6d6b} DynamicQueryHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f4bd4931000, frame address: 0x7f4bd50bb370, stack size: 482448, maximum stack size: 8388608. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000000fa808d4 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000000fa80784 5. ./src/Parsers/TokenIterator.h:81: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af98154 6. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afe44a9 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 8. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af49321 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 10. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afffb52 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 12. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6e5a1 13. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 14. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afe44a9 15. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 16. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af49321 17. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 18. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afffb52 19. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 20. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6e5a1 21. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 22. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afe44a9 23. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 24. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af49321 25. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 26. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afffb52 27. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 28. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6e5a1 29. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 30. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afe44a9 31. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:59.562817 [ 3966 ] {28bff068-cf1c-454f-909b-b51aa4a1813f} executeQuery: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndexUTF8, Integer expected: In scope SELECT substringIndexUTF8('富强,民主,文明', ',', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36572) (comment: 02798_substring_index.sql) (in query: select substringIndexUTF8('富强,民主,文明', ',', cast(2 as Int128));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e298fdd 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:05:59.564431 [ 3966 ] {28bff068-cf1c-454f-909b-b51aa4a1813f} TCPHandler: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndexUTF8, Integer expected: In scope SELECT substringIndexUTF8('富强,民主,文明', ',', CAST(2, 'Int128')). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e298fdd 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007611924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:05:59.588787 [ 2699 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:59.599699 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:05:59.820563 [ 4083 ] {67dcfc3f-f83b-42ae-80b6-05d45463b41c} executeQuery: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54210) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT [[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000001632cbe0 4. ./src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af983ef 5. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:966: DB::ParserNull::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af544c1 6. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 7. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserLiteral::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af58893 8. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 9. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:1356: DB::ParserCollectionOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af66deb 10. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 11. ./src/Parsers/ExpressionElementParsers.h:339: DB::ParserArrayOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001a63d315 12. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 13. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2656: DB::ParserExpressionImpl::tryParseOperand(std::vector>, std::allocator>>>&, DB::IParser::Pos&, DB::Expected&) @ 0x000000001af76b20 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpressionImpl::parse(std::unique_ptr>, DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af74b37 15. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpression::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af744c7 16. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 17. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:2121: DB::ParserWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af60e14 18. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 19. ./src/Parsers/ExpressionListParsers.h:216: DB::ParserExpressionWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6bd8a 20. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6de82 22. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 23. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af70da6 24. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 25. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:327: DB::ParserNotEmptyExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af70f15 26. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 27. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:0: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001b000b22 28. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 29. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afffb85 30. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 31. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6e5a1 2025.06.12 19:05:59.821494 [ 4083 ] {67dcfc3f-f83b-42ae-80b6-05d45463b41c} DynamicQueryHandler: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000001632cbe0 4. ./src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af983ef 5. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:966: DB::ParserNull::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af544c1 6. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 7. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserLiteral::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af58893 8. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 9. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:1356: DB::ParserCollectionOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af66deb 10. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 11. ./src/Parsers/ExpressionElementParsers.h:339: DB::ParserArrayOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001a63d315 12. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 13. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2656: DB::ParserExpressionImpl::tryParseOperand(std::vector>, std::allocator>>>&, DB::IParser::Pos&, DB::Expected&) @ 0x000000001af76b20 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpressionImpl::parse(std::unique_ptr>, DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af74b37 15. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpression::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af744c7 16. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 17. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:2121: DB::ParserWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af60e14 18. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 19. ./src/Parsers/ExpressionListParsers.h:216: DB::ParserExpressionWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6bd8a 20. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6de82 22. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 23. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af70da6 24. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 25. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:327: DB::ParserNotEmptyExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af70f15 26. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 27. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:0: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001b000b22 28. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 29. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001afffb85 30. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af981a1 31. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001af6e5a1 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:05:59.991137 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:00.429415 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:00.589530 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:00.991927 [ 3169 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:01.265498 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:01.590813 [ 3174 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:01.992651 [ 3144 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:02.109981 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:02.591573 [ 3139 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:02.837526 [ 3966 ] {2f6f8e87-7c67-4d82-9b5c-58a32b7f5e92} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55368) (comment: 02845_parquet_odd_decimals.sh) (in query: DROP DATABASE IF EXISTS test_rvygvngp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:02.838753 [ 3966 ] {2f6f8e87-7c67-4d82-9b5c-58a32b7f5e92} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:02.948328 [ 3849 ] {81b4ff22-a36b-47e9-91b3-77c12c92c564} executeQuery: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38780) (comment: 02293_compatibility_ignore_auto_increment_in_create_table.sql) (in query: CREATE TABLE ignore_auto_increment ( id int AUTO_INCREMENT ) ENGINE=MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c38e73 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c39856 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:02.948906 [ 3849 ] {81b4ff22-a36b-47e9-91b3-77c12c92c564} TCPHandler: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c38e73 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c39856 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:02.993366 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:03.008118 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:03.069014 [ 3849 ] {ed650f3b-e414-40d4-b112-0458b858e11f} executeQuery: Code: 57. DB::Exception: Table test_9.ignore_auto_increment already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38780) (comment: 02293_compatibility_ignore_auto_increment_in_create_table.sql) (in query: CREATE TABLE ignore_auto_increment ( id int AUTO_INCREMENT, di AUTO_INCREMENT, s String AUTO_INCREMENT ) ENGINE=MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:03.069422 [ 3849 ] {ed650f3b-e414-40d4-b112-0458b858e11f} TCPHandler: Code: 57. DB::Exception: Table test_9.ignore_auto_increment already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:03.592296 [ 3090 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:03.712326 [ 3966 ] {4a5d733d-834b-469b-912a-136b5763ab7b} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38802) (comment: 02885_arg_min_max_combinator.sql) (in query: select sumArgMin() from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:0: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000015d50c2e 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b134 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000162292ab 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:03.713117 [ 3966 ] {4a5d733d-834b-469b-912a-136b5763ab7b} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:0: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000015d50c2e 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b134 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000162292ab 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:03.922027 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:03.970573 [ 3966 ] {4dc5c8a8-250a-4d26-a131-b99d2a9b65b4} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38802) (comment: 02885_arg_min_max_combinator.sql) (in query: select sumArgMin(number) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/AggregateFunctions/FactoryHelpers.h:27: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000014e912a8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 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 @ 0x00000000162292ab 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b18b 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 @ 0x00000000162292ab 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:06:03.971241 [ 3966 ] {4dc5c8a8-250a-4d26-a131-b99d2a9b65b4} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/AggregateFunctions/FactoryHelpers.h:27: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000014e912a8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364a27e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622b46c 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 @ 0x00000000162292ab 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:249: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b18b 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 @ 0x00000000162292ab 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:06:03.994013 [ 3192 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:04.212576 [ 3966 ] {1c680921-ba7f-4517-a601-26b585ef1ad7} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(sum, UInt64) for combinator sumArgMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38802) (comment: 02885_arg_min_max_combinator.sql) (in query: -- Try passing a non comparable type, for example an AggregationState select sumArgMin(number, unhex('0000000000000000')::AggregateFunction(sum, UInt64)) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:0: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000015d512e6 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b1e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000162292ab 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:04.213300 [ 3966 ] {1c680921-ba7f-4517-a601-26b585ef1ad7} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(sum, UInt64) for combinator sumArgMin because the values of that data type are not comparable. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:0: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000015d512e6 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000001622b1e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000162292ab 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bac2a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:04.592952 [ 3061 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:04.747457 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:04.975880 [ 3966 ] {d5d1263c-9b46-49b7-9dd5-ab4b8c97c1dc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55402) (comment: 00972_desc_table_virtual_columns.sql) (in query: DROP DATABASE IF EXISTS test_5kwi1gzs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:04.976621 [ 3966 ] {d5d1263c-9b46-49b7-9dd5-ab4b8c97c1dc} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:05.031789 [ 3048 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:05.590329 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:05.593764 [ 3019 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:06.032514 [ 3007 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:06.474029 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:06.594608 [ 3022 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:06.733182 [ 3966 ] {8c863099-e06c-428c-b438-5e5e68a95081} executeQuery: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e958ab 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:06.733766 [ 3966 ] {8c863099-e06c-428c-b438-5e5e68a95081} TCPHandler: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e958ab 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.033358 [ 2973 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:07.066302 [ 3966 ] {871da3e6-6de8-4b7b-af5d-c4d593be6548} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('::1]', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.067076 [ 3966 ] {871da3e6-6de8-4b7b-af5d-c4d593be6548} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.074778 [ 3966 ] {47f26545-4031-49e0-bb7e-e6f15a08f085} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('::1', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.075343 [ 3966 ] {47f26545-4031-49e0-bb7e-e6f15a08f085} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.288390 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.543262 [ 3966 ] {202a48c9-7ca9-4067-9f4b-187b1b8eb7f0} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1][::1]', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e9612b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.544057 [ 3966 ] {202a48c9-7ca9-4067-9f4b-187b1b8eb7f0} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e9612b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.551840 [ 3966 ] {72a485e4-ef3c-4f4e-a459-cead1ad773a7} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1][::1', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e9612b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.552328 [ 3966 ] {72a485e4-ef3c-4f4e-a459-cead1ad773a7} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e9612b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.595542 [ 3002 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:07.637840 [ 3966 ] {41039e18-20fd-406e-9198-5ca97e69fa67} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1]::1]', 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.638359 [ 3966 ] {41039e18-20fd-406e-9198-5ca97e69fa67} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.683445 [ 3966 ] {5e5d8c7c-9552-4d6c-bf71-bd8b21a4c49f} executeQuery: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e958ab 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.683867 [ 3966 ] {5e5d8c7c-9552-4d6c-bf71-bd8b21a4c49f} TCPHandler: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e958ab 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.689378 [ 3966 ] {58149ce1-6edf-42c4-9da2-43b8d9aef731} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.689770 [ 3966 ] {58149ce1-6edf-42c4-9da2-43b8d9aef731} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.695087 [ 3966 ] {e27c431b-b2ac-4f8a-8cd0-4752114b9a70} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.695698 [ 3966 ] {e27c431b-b2ac-4f8a-8cd0-4752114b9a70} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.701761 [ 3966 ] {cc14a5ce-e0eb-4e78-a7ea-e33fba041532} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1][::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e9612b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.702264 [ 3966 ] {cc14a5ce-e0eb-4e78-a7ea-e33fba041532} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e9612b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.708541 [ 3966 ] {c35cab71-b233-457a-b78d-4e8b1f0b4aa1} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1][::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e9612b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.709027 [ 3966 ] {c35cab71-b233-457a-b78d-4e8b1f0b4aa1} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e9612b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.714359 [ 3966 ] {95c85974-7108-4d6a-954b-6a2f53146b3e} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38864) (comment: 01880_remote_ipv6.sql) (in query: SELECT * FROM remote('[::1]::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:07.752870 [ 3966 ] {95c85974-7108-4d6a-954b-6a2f53146b3e} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000761fd20 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x0000000015e95b3a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001757a2f1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001758e329 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001758504a 8. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:291: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015e58e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001749e433 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174ce619 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749154f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:08.034061 [ 2934 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:08.102981 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:08.596269 [ 3045 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:08.721986 [ 3966 ] {9bfbdbf5-27cf-4465-801c-7494993a00d2} executeQuery: Code: 57. DB::Exception: Table test_515rn6mv.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38910) (comment: 02461_mullable_pk_monotonicity_bug.sql) (in query: CREATE TABLE tab (`x` LowCardinality(UInt8)) ENGINE = MergeTree ORDER BY x SETTINGS allow_nullable_key = 1, index_granularity = 2, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 230486175, compact_parts_max_granules_to_buffer = 86, compact_parts_merge_max_bytes_to_prefetch_part = 4712962, merge_max_block_size = 2284, old_parts_lifetime = 115., prefer_fetch_merged_part_size_threshold = 2994664791, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5898897237, index_granularity_bytes = 27738296, concurrent_part_removal_threshold = 11, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 78046, primary_key_compress_block_size = 46455), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:08.723524 [ 3966 ] {9bfbdbf5-27cf-4465-801c-7494993a00d2} TCPHandler: Code: 57. DB::Exception: Table test_515rn6mv.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:08.788448 [ 3966 ] {b30dda32-045e-4715-a889-4ad9a2c836f6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55460) (comment: 02461_mullable_pk_monotonicity_bug.sql) (in query: DROP DATABASE IF EXISTS test_515rn6mv ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:08.789187 [ 3966 ] {b30dda32-045e-4715-a889-4ad9a2c836f6} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:08.962855 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:09.042192 [ 2911 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:09.596921 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:09.735313 [ 3849 ] {5a3ace15-e8dd-4d9b-872b-efe829e5b97b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38890) (comment: 02941_projections_external_aggregation.sql) (in query: SELECT k1, k2, k3, sum(value) v FROM t_proj_external GROUP BY k1, k2, k3 ORDER BY k1, k2, k3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:891: DB::MergeTreeDataSelectExecutor::estimateNumMarksToRead(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>) const @ 0x0000000019af33ac 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:244: DB::QueryPlanOptimizations::analyzeProjectionCandidate(DB::QueryPlanOptimizations::ProjectionCandidate&, DB::ReadFromMergeTree const&, DB::MergeTreeDataSelectExecutor const&, std::vector> const&, DB::RangesInDataParts const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr, std::equal_to, std::allocator>>> const&, DB::ActionsDAG const*) @ 0x000000001aa274cd 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:675: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1bab8 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:09.736509 [ 3849 ] {5a3ace15-e8dd-4d9b-872b-efe829e5b97b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:891: DB::MergeTreeDataSelectExecutor::estimateNumMarksToRead(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>) const @ 0x0000000019af33ac 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:244: DB::QueryPlanOptimizations::analyzeProjectionCandidate(DB::QueryPlanOptimizations::ProjectionCandidate&, DB::ReadFromMergeTree const&, DB::MergeTreeDataSelectExecutor const&, std::vector> const&, DB::RangesInDataParts const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr, std::equal_to, std::allocator>>> const&, DB::ActionsDAG const*) @ 0x000000001aa274cd 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:675: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1bab8 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:09.825822 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:10.043070 [ 2883 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:10.597670 [ 2868 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:10.661052 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:11.044051 [ 2866 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:11.484644 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:11.598466 [ 2847 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:12.044777 [ 2849 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:12.337116 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:12.599666 [ 2835 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:13.045471 [ 2820 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:13.220339 [ 3966 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:13.490941 [ 4083 ] {beb0882f-eb89-4600-a671-3dd01f5d119f} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('('): ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. Unmatched parentheses: ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54216) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000007648aa3 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) @ 0x000000001b0167f0 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b0168af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182130ab 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&)>) @ 0x000000001821af79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:13.491963 [ 4083 ] {beb0882f-eb89-4600-a671-3dd01f5d119f} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('('): ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. Unmatched parentheses: ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000007648aa3 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) @ 0x000000001b0167f0 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b0168af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182130ab 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&)>) @ 0x000000001821af79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:13.600502 [ 2787 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:14.046118 [ 2754 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:14.055372 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:14.562126 [ 4083 ] {05652006-0205-44ef-9cb6-de82986286e2} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55692) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT 1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000821f800 4. ./build_docker/./src/Parsers/IAST.cpp:157: DB::IAST::checkDepthImpl(unsigned long) const @ 0x000000001af96148 5. ./src/Parsers/IAST.h:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000001b0152f2 6. ./build_docker/./src/Parsers/parseQuery.cpp:400: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001b016770 7. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b0168af 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182130ab 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&)>) @ 0x000000001821af79 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:14.563725 [ 4083 ] {05652006-0205-44ef-9cb6-de82986286e2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000821f800 4. ./build_docker/./src/Parsers/IAST.cpp:157: DB::IAST::checkDepthImpl(unsigned long) const @ 0x000000001af96148 5. ./src/Parsers/IAST.h:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000001b0152f2 6. ./build_docker/./src/Parsers/parseQuery.cpp:400: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001b016770 7. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b0168af 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182130ab 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&)>) @ 0x000000001821af79 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:14.601473 [ 2809 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:14.906772 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:15.047860 [ 2748 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:15.602647 [ 3181 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:15.749345 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:16.048918 [ 2712 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:16.603472 [ 2705 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:16.653512 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:17.050076 [ 2721 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:17.529663 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:17.551087 [ 3966 ] {38915989-cbd1-44a2-b495-83a55ec90dea} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=4): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45794) (comment: 02246_is_secure_query_log.sh) (in query: select interface, is_secure from system.query_log where query_id = '2246_test_9_client_nonsecure' and type = 'QueryFinish' 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001702104f 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 2025.06.12 19:06:17.554458 [ 3966 ] {38915989-cbd1-44a2-b495-83a55ec90dea} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=4): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001702104f 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 2025.06.12 19:06:17.604136 [ 3166 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:18.050939 [ 3151 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:18.352781 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:18.499602 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {751051e6-adca-4665-9806-ed7c89ce0982::202506_1_104_23}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:18.605267 [ 3118 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:19.051621 [ 3099 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:19.175873 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:19.606157 [ 3094 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:20.053590 [ 3071 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:20.103498 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:20.553191 [ 5779 ] {5b2ef377-e5a5-4fe1-b150-061da55cc120} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45892) (comment: 01657_array_element_ubsan.sql) (in query: SELECT '---';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:20.554781 [ 5779 ] {5b2ef377-e5a5-4fe1-b150-061da55cc120} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:20.607184 [ 3048 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:20.890691 [ 5779 ] {97a6bf86-bb7f-4563-a82b-4fc74513e03d} 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.10057.altinitytest (altinity build)) (from [::1]:45906) (comment: 02246_is_secure_query_log.sh) (in query: select interface, is_secure from system.query_log where query_id = '2246_test_9_client_secure' and type = 'QueryFinish' 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:20.893309 [ 5779 ] {97a6bf86-bb7f-4563-a82b-4fc74513e03d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:20.925210 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:21.054537 [ 3026 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:21.307460 [ 20807 ] {c653ff4c-4224-4f5d-95de-86cb746c4b48} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43706) (comment: 03017_analyzer_groupby_fuzz_61600.sql) (in query: DROP DATABASE IF EXISTS test_6vgpnsqm ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:21.308332 [ 20807 ] {c653ff4c-4224-4f5d-95de-86cb746c4b48} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:21.314128 [ 4203 ] {3e980351-b0b0-4f0b-9826-de020adf1449} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43720) (comment: 03017_analyzer_groupby_fuzz_61600.sql) (in query: DROP DATABASE IF EXISTS test_6vgpnsqm ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:21.315061 [ 4203 ] {3e980351-b0b0-4f0b-9826-de020adf1449} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:21.607987 [ 3001 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:21.755902 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:21.944922 [ 4203 ] {98b65003-9363-42aa-8484-40a3562b9e4f} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36374) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:0: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001a9ca871 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9c9135 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:21.945613 [ 4203 ] {98b65003-9363-42aa-8484-40a3562b9e4f} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:0: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001a9ca871 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9c9135 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:21.949783 [ 20807 ] {f24fca2b-fb7b-4a9b-97cb-7123f312d640} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:0: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001a9ca871 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9c9135 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 : While executing Remote. (TOO_MANY_ROWS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45948) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.1', system.numbers) LIMIT 100) SETTINGS max_rows_to_read_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:21.950949 [ 20807 ] {f24fca2b-fb7b-4a9b-97cb-7123f312d640} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:0: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001a9ca871 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9c9135 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 : While executing Remote. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.045834 [ 4203 ] {42b4708a-35de-4b56-a954-671a791f73f6} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47582) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb76b 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.046594 [ 4203 ] {42b4708a-35de-4b56-a954-671a791f73f6} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb76b 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.049917 [ 20807 ] {7b442484-29f4-42e8-8adf-d431e5f73fa1} executeQuery: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb76b 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 : While executing Remote. (TOO_MANY_BYTES) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45948) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.1', system.numbers) LIMIT 100) SETTINGS max_bytes_to_read_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.051070 [ 20807 ] {7b442484-29f4-42e8-8adf-d431e5f73fa1} TCPHandler: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb76b 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 : While executing Remote. (TOO_MANY_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.055495 [ 2995 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:22.206119 [ 3849 ] {0593b30d-8ae6-4c53-9c50-5a7a33ab7e0e} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58750) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:0: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001a9ca871 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9c9135 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.206925 [ 3849 ] {0593b30d-8ae6-4c53-9c50-5a7a33ab7e0e} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:0: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001a9ca871 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9c9135 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.210372 [ 20807 ] {dc1202c1-a877-487e-8a1c-567a0e070407} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:0: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001a9ca871 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9c9135 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 : While executing Remote. (TOO_MANY_ROWS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45948) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.2', system.numbers) LIMIT 100) SETTINGS max_rows_to_read_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.211531 [ 20807 ] {dc1202c1-a877-487e-8a1c-567a0e070407} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e31f0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31ba3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e31e7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:0: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001a9ca871 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9c9135 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 : While executing Remote. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.317495 [ 3849 ] {5a2eddac-6837-4466-9e65-8c74514621b2} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58754) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb76b 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.317971 [ 3849 ] {5a2eddac-6837-4466-9e65-8c74514621b2} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb76b 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.320778 [ 20807 ] {eda21509-1424-4376-82a1-75729902ae3a} executeQuery: Code: 307. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb76b 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 : While executing Remote. (TOO_MANY_BYTES) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45948) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.2', system.numbers) LIMIT 100) SETTINGS max_bytes_to_read_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.321922 [ 20807 ] {eda21509-1424-4376-82a1-75729902ae3a} TCPHandler: Code: 307. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e3204c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e31cd0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfb76b 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0ddd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 : While executing Remote. (TOO_MANY_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.467196 [ 3849 ] {8027f63b-e176-4f95-b663-385ffd20bec5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58758) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.467738 [ 3849 ] {8027f63b-e176-4f95-b663-385ffd20bec5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.471049 [ 20807 ] {b520c5b4-fc8b-4120-b2a0-a7af6a584fca} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45948) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.2', system.numbers) LIMIT 100) SETTINGS max_rows_to_read_leaf=100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.472247 [ 20807 ] {b520c5b4-fc8b-4120-b2a0-a7af6a584fca} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=770). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 : 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fa9ded4 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a045de2 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a050134 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0aefde 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2da5f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e2d560 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e2c0c3 2025.06.12 19:06:22.601709 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:22.608762 [ 3015 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:23.056215 [ 2964 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:23.512818 [ 5779 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:23.610108 [ 2960 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:24.057123 [ 2956 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:24.337671 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:24.611120 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:25.057899 [ 2899 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:25.159232 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:25.611797 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:25.986770 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:26.058802 [ 3170 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:26.612491 [ 2852 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:26.717076 [ 3849 ] {7b52c34e-1ab8-4bb7-84ee-f4b658ec4ce5} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_48sotal8.test_constraints (66be5096-d068-4fcf-aac0-4b4d7ff3143d) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47994) (comment: 00953_constraints_operations.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000016fd2a5c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001a66d23c 5. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 12. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 13. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:26.718108 [ 3849 ] {7b52c34e-1ab8-4bb7-84ee-f4b658ec4ce5} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_48sotal8.test_constraints (66be5096-d068-4fcf-aac0-4b4d7ff3143d) is violated at row 1. 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000016fd2a5c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001a66d23c 5. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 12. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 13. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:26.863376 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:27.059395 [ 3039 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:27.613596 [ 2824 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:27.709882 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:28.060135 [ 2821 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:28.567439 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:28.614362 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:29.002507 [ 20807 ] {b2dccec5-ad5f-4cec-8b52-a43bb4effe51} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_48sotal8.test_constraints (66be5096-d068-4fcf-aac0-4b4d7ff3143d) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48112) (comment: 00953_constraints_operations.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000016fd2a5c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001a66d23c 5. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 12. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 13. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:29.003414 [ 20807 ] {b2dccec5-ad5f-4cec-8b52-a43bb4effe51} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_48sotal8.test_constraints (66be5096-d068-4fcf-aac0-4b4d7ff3143d) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000016fd2a5c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001a66d23c 5. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 12. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 13. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:29.060842 [ 2759 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:29.411467 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:29.615433 [ 3107 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:30.061643 [ 2737 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:30.100759 [ 4083 ] {b84da585-bb6a-4bce-87cf-2b9f743f2f57} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49492) (comment: 00953_constraints_operations.sh) (in query: DROP DATABASE IF EXISTS test_48sotal8 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:30.101444 [ 4083 ] {b84da585-bb6a-4bce-87cf-2b9f743f2f57} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:30.107724 [ 20807 ] {91765dc5-82e9-4534-9077-3535f3f1e733} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49500) (comment: 00953_constraints_operations.sh) (in query: DROP DATABASE IF EXISTS test_48sotal8 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:30.108462 [ 20807 ] {91765dc5-82e9-4534-9077-3535f3f1e733} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:30.132644 [ 4083 ] {99a95a4b-b89c-4c6c-b585-694fea133d04} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:49504) (comment: 00953_constraints_operations.sh) (in query: DROP DATABASE IF EXISTS test_48sotal8 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:30.133545 [ 4083 ] {99a95a4b-b89c-4c6c-b585-694fea133d04} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:30.292309 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:30.604692 [ 3271 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4f333495-acfb-4268-babd-cccac1f9f301::all_1_5_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:30.616237 [ 2717 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:31.062424 [ 2715 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:31.147962 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:31.617073 [ 2687 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:31.971122 [ 20807 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:32.063434 [ 3172 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:32.255343 [ 4083 ] {97eabf02-a484-4323-817e-aac8616b4520} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50986) (comment: 02542_table_function_format.sql) (in query: create table test as format(TSV, 'cust_id UInt128', '20210129005809043707\n123456789\n987654321');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:32.256243 [ 4083 ] {97eabf02-a484-4323-817e-aac8616b4520} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:32.617774 [ 3160 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:32.921987 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:33.064018 [ 3144 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:33.342148 [ 4083 ] {c0f75216-c827-4276-8d12-44a29f52a776} executeQuery: Code: 60. DB::Exception: Table `test_ionlee1e`.`test_ionlee1e` doesn't exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51020) (comment: 02891_rename_table_without_keyword.sql) (in query: RENAME TABLE test_ionlee1e TO test_ionlee1e_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000001712f00c 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:269: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x00000000170ae476 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000017d50d8a 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000017d4f564 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:33.342871 [ 4083 ] {c0f75216-c827-4276-8d12-44a29f52a776} TCPHandler: Code: 60. DB::Exception: Table `test_ionlee1e`.`test_ionlee1e` doesn't 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000001712f00c 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:269: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x00000000170ae476 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000017d50d8a 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000017d4f564 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:33.363318 [ 4083 ] {5a98738f-4829-4418-b1c8-afa7567b4b29} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51020) (comment: 02891_rename_table_without_keyword.sql) (in query: DROP DATABASE IF EXISTS test_ionlee1e), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:33.363723 [ 4083 ] {5a98738f-4829-4418-b1c8-afa7567b4b29} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:33.441255 [ 23467 ] {dd0e229a-5958-465e-8fa5-f23b942d2620} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45238) (comment: 02891_rename_table_without_keyword.sql) (in query: DROP DATABASE IF EXISTS test_ionlee1e ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:33.442192 [ 23467 ] {dd0e229a-5958-465e-8fa5-f23b942d2620} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6c8a0 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>>>&) @ 0x0000000017c6e9aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:33.618828 [ 3133 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:33.787078 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:34.064739 [ 3111 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:34.274181 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:34.606073 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:34.619500 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:34.671244 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:35.065510 [ 3051 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:35.498957 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:35.515756 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:35.620508 [ 3029 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:36.066395 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:36.343398 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:36.408571 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:36.621256 [ 2995 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:37.067820 [ 2988 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:37.192721 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:37.248258 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:37.621993 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:38.057151 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:38.068646 [ 2971 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:38.088530 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:38.609006 [ 23792 ] {7036452c-25d7-437d-88bf-263e89ff90bc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51068) (comment: 01524_do_not_merge_across_partitions_select_final.sql) (in query: SELECT max(x) FROM select_final 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:38.614907 [ 23792 ] {7036452c-25d7-437d-88bf-263e89ff90bc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:38.622898 [ 2951 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:38.693754 [ 4083 ] {34905ac3-e02f-4782-aa35-0ecc62c6270f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45312) (comment: 01524_do_not_merge_across_partitions_select_final.sql) (in query: DROP DATABASE IF EXISTS test_9vkire2s ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:38.694753 [ 4083 ] {34905ac3-e02f-4782-aa35-0ecc62c6270f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:38.703044 [ 23927 ] {1be84b40-3de6-4d7a-bcfb-9e1e7c636098} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45328) (comment: 01524_do_not_merge_across_partitions_select_final.sql) (in query: DROP DATABASE IF EXISTS test_9vkire2s ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:38.703941 [ 23927 ] {1be84b40-3de6-4d7a-bcfb-9e1e7c636098} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:38.915808 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:38.922053 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:39.069461 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:39.624020 [ 2902 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:39.776844 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:39.816909 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:39.883723 [ 23952 ] {af6e8640-6f9b-408a-9d8e-47168461461b} executeQuery: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(FQDN()). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51318) (comment: 01459_default_value_of_argument_type_nullptr_dereference.sql) (in query: SELECT defaultValueOfTypeName(FQDN());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionDefaultValueOfTypeName::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009588f3e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 2025.06.12 19:06:39.884468 [ 23952 ] {af6e8640-6f9b-408a-9d8e-47168461461b} TCPHandler: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(FQDN()). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. DB::(anonymous namespace)::FunctionDefaultValueOfTypeName::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009588f3e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076321fa 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 2025.06.12 19:06:40.070416 [ 2895 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:40.292772 [ 23952 ] {b8352494-46b6-4072-af53-2f4935528ecb} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51352) (comment: 01825_type_json_18.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:40.294099 [ 23952 ] {b8352494-46b6-4072-af53-2f4935528ecb} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:40.613154 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:40.624808 [ 3170 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:40.639477 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:41.071291 [ 2861 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:41.445466 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:41.478037 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:41.625601 [ 2837 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:41.768402 [ 23927 ] {946ec2e7-c595-4654-9493-062d9c13ac60} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45382) (comment: 01114_alter_modify_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_mo8dp7b6 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:41.769348 [ 23927 ] {946ec2e7-c595-4654-9493-062d9c13ac60} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:41.779966 [ 23952 ] {7c39e187-fd76-4cd0-ba84-655c9d86e94c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45388) (comment: 01114_alter_modify_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_mo8dp7b6 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:41.781067 [ 23952 ] {7c39e187-fd76-4cd0-ba84-655c9d86e94c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:41.791064 [ 23927 ] {716279f5-da06-4166-bf69-a37dcb476aae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45404) (comment: 01114_alter_modify_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_mo8dp7b6 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:41.792084 [ 23927 ] {716279f5-da06-4166-bf69-a37dcb476aae} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c6e66e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:42.086702 [ 2819 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:42.167387 [ 23467 ] {a9f4ad54-f13a-4028-8f9e-de4c176b6f0a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40048) (comment: 02267_join_dup_columns_issue36199.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:42.168297 [ 23467 ] {a9f4ad54-f13a-4028-8f9e-de4c176b6f0a} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:42.291449 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:42.330839 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:42.626422 [ 2789 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:43.087402 [ 2807 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:43.170123 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:43.223593 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:43.258977 [ 23927 ] {84e4da46-a73a-46c5-89ef-3b6760b03cfe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40088) (comment: 00275_shard_quantiles_weighted.sql) (in query: SELECT quantilesExactWeighted(0, 0.001, 0.01, 0.05, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 0.95, 0.99, 0.999, 1)(number, 1) FROM remote('127.0.0.{2,3}', currentDatabase(), numbers_1001);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:43.259750 [ 23927 ] {84e4da46-a73a-46c5-89ef-3b6760b03cfe} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:43.627469 [ 3129 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:43.636010 [ 23467 ] {2b5bb8bc-ede8-4a3a-850f-c351e58a4f6f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40126) (comment: 00174_distinct_in_order.sql) (in query: select '-- check that distinct with and w/o optimization produce the same result';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:43.637045 [ 23467 ] {2b5bb8bc-ede8-4a3a-850f-c351e58a4f6f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:43.998865 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:44.088088 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:44.098985 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:44.628203 [ 2748 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:44.825113 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:44.990771 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:45.088859 [ 2810 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:45.629032 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:45.647357 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:45.848698 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:46.089518 [ 2687 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:46.482885 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:46.629768 [ 2683 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:46.675383 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:46.981811 [ 23927 ] {9d0e3e27-8340-4def-bc0a-6983526926b7} 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.10057.altinitytest (altinity build)) (from [::1]:40244) (comment: 01930_optimize_skip_unused_shards_rewrite_in.sql) (in query: -- UInt8, Int8 select _shard_num, * from remote('127.{1..4}', view(select toUInt8(id) id from data), toInt8(id)) where id in (0, 1, 0x7f, 0x80, 0xff) order by _shard_num, id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:46.983388 [ 23927 ] {9d0e3e27-8340-4def-bc0a-6983526926b7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:47.090251 [ 3175 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:47.323543 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:47.522052 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:47.612865 [ 23467 ] {43b5fe1e-79e0-4048-ae20-5897a920adf7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60176) (comment: 01917_distinct_on.sql) (in query: DROP DATABASE IF EXISTS test_dmpul30z ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:47.614243 [ 23467 ] {43b5fe1e-79e0-4048-ae20-5897a920adf7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:47.630457 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:48.091157 [ 3148 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:48.166714 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:48.356728 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:48.445332 [ 23467 ] {89dbb03b-87ff-425d-8758-61e0bc7d2cc6} 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.10057.altinitytest (altinity build)) (from [::1]:40300) (comment: 01710_projection_with_mixed_pipeline.sql) (in query: select uniqHLL12(x) from t settings optimize_use_projections = 1, max_bytes_to_read=400, max_block_size=8;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1a787 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:48.445923 [ 23467 ] {89dbb03b-87ff-425d-8758-61e0bc7d2cc6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1a787 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:48.631306 [ 3119 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:49.018233 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:49.092097 [ 3122 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:49.190252 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:49.633298 [ 3105 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:49.853386 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:50.028826 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:50.093267 [ 3080 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:50.659705 [ 23467 ] {349e89b0-f94d-44a0-ac4a-3559795e8a91} 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.10057.altinitytest (altinity build)) (from [::1]:40404) (comment: 00172_hits_joins.gen.sql) (in query: SELECT EventDate, hits, visits FROM ( SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate ) ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:50.662088 [ 23467 ] {349e89b0-f94d-44a0-ac4a-3559795e8a91} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:50.671788 [ 3060 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:50.681284 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:50.860051 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:51.094188 [ 3062 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:51.319522 [ 23467 ] {695b6c88-9c9f-4873-9fe2-7f2c8ab0334d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40444) (comment: 00089_position_functions_with_non_constant_arg.sql) (in query: SELECT count() FROM test.hits WHERE positionCaseInsensitiveUTF8(Title, 'новости') != positionCaseInsensitiveUTF8(Title, materialize('новости'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:51.320758 [ 23467 ] {695b6c88-9c9f-4873-9fe2-7f2c8ab0334d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:51.580255 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:51.672615 [ 3187 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:51.756536 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:52.094967 [ 3026 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:52.434104 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:52.596239 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:52.673305 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:53.095790 [ 3024 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:53.335492 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:53.473133 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:53.674263 [ 3015 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:53.781889 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_141_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:54.096456 [ 2970 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:54.175271 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:54.429165 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:54.674976 [ 2948 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:55.029722 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:55.097338 [ 3196 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:55.289690 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:55.675785 [ 2911 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:55.924125 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:56.097988 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:56.120097 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:56.676552 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:56.741469 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:56.952931 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:57.099042 [ 2890 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:57.583710 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:57.677340 [ 2872 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:57.799830 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:58.099919 [ 2865 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:58.407418 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:58.491277 [ 23467 ] {c187acb2-3f2b-4011-8ab9-9d15e0ca2933} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33030) (comment: 00177_memory_bound_merging.sh) (in query: SELECT COUNT() > 0 FROM system.text_log WHERE query_id IN (SELECT query_id FROM system.query_log WHERE query_id != 'query_id_memory_bound_merging_83544628' AND initial_query_id = 'query_id_memory_bound_merging_83544628' AND event_date >= yesterday()) AND event_date >= yesterday() AND message ILIKE '%Reading%ranges in order%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:58.493067 [ 23467 ] {c187acb2-3f2b-4011-8ab9-9d15e0ca2933} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:58.645177 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:58.678184 [ 2859 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:59.100686 [ 2832 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:06:59.238854 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:59.481556 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:06:59.679062 [ 2791 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:00.101315 [ 2782 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:00.152051 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:00.329305 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:00.679896 [ 2767 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:00.991112 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:01.102167 [ 2759 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:01.181472 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:01.418721 [ 23792 ] {4c46608f-8dd7-429d-8148-185485c0c3ba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=771). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33302) (comment: 00159_parallel_formatting_tsv_and_friends.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a, MobilePhoneModel as b, ClientIP6 as c FROM test.hits ORDER BY a, b, c LIMIT 3000000 Format TSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:01.426975 [ 23792 ] {4c46608f-8dd7-429d-8148-185485c0c3ba} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=771). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:01.680604 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:01.854756 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:02.029767 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:02.103147 [ 2788 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:02.681310 [ 2736 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:02.704310 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:02.863057 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:03.103905 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:03.575955 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:03.681898 [ 2702 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:03.736097 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:04.104621 [ 3176 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:04.408799 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:04.570838 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:04.639680 [ 23467 ] {081daec7-544f-41a3-89e3-e62d3812132f} executeQuery: Code: 57. DB::Exception: Table test.hits_dst already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42568) (comment: 00061_storage_buffer.sql) (in query: CREATE TABLE test.hits_dst AS test.hits ENGINE = MergeTree PARTITION BY toYYYYMM(EventDate) ORDER BY (CounterID, EventDate, intHash32(UserID)) SAMPLE BY intHash32(UserID) SETTINGS storage_policy = 'default', index_granularity = 42394, min_bytes_for_wide_part = 374798606, 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 = 343109641, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 22543745, merge_max_block_size = 17265, old_parts_lifetime = 89., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 19087667, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 28026, primary_key_compress_block_size = 62680), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:04.641894 [ 23467 ] {081daec7-544f-41a3-89e3-e62d3812132f} TCPHandler: Code: 57. DB::Exception: Table test.hits_dst already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:04.682801 [ 3148 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:05.105312 [ 3123 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:05.371076 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:05.448431 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:05.683657 [ 3099 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:06.106382 [ 3085 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:06.196192 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:06.336194 [ 23467 ] {21ee7215-f510-471d-af1b-ef3093b21bbc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=772). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42640) (comment: 00082_quantiles.sql) (in query: SELECT CounterID AS k, quantilesTiming(0.1, 0.5, 0.9, 0.99, 0.999)(ResolutionWidth) FROM test.hits GROUP BY k ORDER BY count() DESC, CounterID LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:06.336478 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:06.337335 [ 23467 ] {21ee7215-f510-471d-af1b-ef3093b21bbc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:06.456173 [ 4083 ] {b03a5737-7804-44ea-b890-a335fc9123d6} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Exception: Unsupported language for region name. Supported languages are: 'ru', 'en', 'ua', 'uk', 'by', 'kz', 'tr', 'de', 'uz', 'lv', 'lt', 'et', 'pt', 'he', 'vi', 'es'. (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42628) (comment: 02411_legacy_geobase.sql) (in query: SELECT regionToName(number::UInt32, 'xy') FROM numbers(13);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String&&, int) @ 0x000000001e594ee3 1. DB::RegionsNames::getLanguageEnum(String const&) @ 0x0000000007b8a022 2. DB::FunctionRegionToName::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b889ec 3. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 4. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:06.456853 [ 4083 ] {b03a5737-7804-44ea-b890-a335fc9123d6} TCPHandler: Code: 1000. DB::Exception: Exception: Unsupported language for region name. Supported languages are: 'ru', 'en', 'ua', 'uk', 'by', 'kz', 'tr', 'de', 'uz', 'lv', 'lt', 'et', 'pt', 'he', 'vi', 'es'. (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&&, int) @ 0x000000001e594ee3 1. DB::RegionsNames::getLanguageEnum(String const&) @ 0x0000000007b8a022 2. DB::FunctionRegionToName::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b889ec 3. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 4. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173f4c46 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173f305f 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a693b4a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8c4b47 12. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x0000000016238aa2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dcc3a5 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc5597 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:06.540000 [ 4083 ] {50c81936-7880-40e9-863c-34f6fbd7e825} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=772). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42628) (comment: 02411_legacy_geobase.sql) (in query: SELECT regionToName(number::UInt32, 'en'), regionToDistrict(number::UInt32) AS id, regionToName(id, 'en') FROM numbers(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:06.540441 [ 4083 ] {50c81936-7880-40e9-863c-34f6fbd7e825} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:06.684434 [ 3077 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:07.018342 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:07.107411 [ 3054 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:07.162989 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:07.436741 [ 24824 ] {de45b9b2-56c5-4372-86d8-16c0b40f7732} executeQuery: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_xg1p9duz.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42720) (comment: 02694_wrong_identifier_shouldnt_be_accepted.sql) (in query: SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE (t1.d >= now());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x00000000175205b4 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001751906e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017519f4d 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bfdd 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751a791 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bff0 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751a791 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bff0 11. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000001751e3f7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174ab47a 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499e4e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5108 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017491889 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 19:07:07.437469 [ 24824 ] {de45b9b2-56c5-4372-86d8-16c0b40f7732} TCPHandler: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_xg1p9duz.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x00000000175205b4 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001751906e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017519f4d 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bfdd 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751a791 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bff0 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751a791 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bff0 11. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000001751e3f7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174ab47a 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499e4e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5108 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017491889 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 19:07:07.631663 [ 23467 ] {cee75589-c76b-4fe8-8540-07bf045761c1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42876) (comment: 02694_wrong_identifier_shouldnt_be_accepted.sql) (in query: DROP DATABASE IF EXISTS test_xg1p9duz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:07.632739 [ 23467 ] {cee75589-c76b-4fe8-8540-07bf045761c1} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:07.646817 [ 4083 ] {8b2f50b9-c81a-496b-b427-b63a99909abc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42892) (comment: 02694_wrong_identifier_shouldnt_be_accepted.sql) (in query: DROP DATABASE IF EXISTS test_xg1p9duz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:07.647701 [ 4083 ] {8b2f50b9-c81a-496b-b427-b63a99909abc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:07.654907 [ 4083 ] {f2561c79-cf43-41f3-9925-2fc1c4c9480a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42904) (comment: 02694_wrong_identifier_shouldnt_be_accepted.sql) (in query: DROP DATABASE IF EXISTS test_xg1p9duz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:07.655631 [ 4083 ] {f2561c79-cf43-41f3-9925-2fc1c4c9480a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:07.671861 [ 24824 ] {40a10756-244e-47de-b8f5-71a1da66b8a9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42912) (comment: 02694_wrong_identifier_shouldnt_be_accepted.sql) (in query: DROP DATABASE IF EXISTS test_xg1p9duz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:07.672847 [ 24824 ] {40a10756-244e-47de-b8f5-71a1da66b8a9} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:07.685560 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:07.955138 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:07.989352 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:08.110688 [ 3049 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:08.683101 [ 2656 ] {mysql:2:e123ec88-7fe2-478d-8724-f2ff04c44e2f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48556) (in query: SELECT `key` FROM `test_iimmzbkq`.`foo`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:08.684652 [ 2656 ] {} MySQLHandler: MySQLHandler: Cannot read packet: : 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:08.685510 [ 17249 ] {0bc6edc4-65f8-48a1-8936-0cca2da87804} MySQLSource: Error processing query 'SELECT `key` FROM `test_iimmzbkq`.`foo`': mysqlxx::BadQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) while executing query: 'SELECT `key` FROM `test_iimmzbkq`.`foo`' (127.0.0.1:9004) 2025.06.12 19:07:08.686259 [ 2973 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:08.777516 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:08.860871 [ 23792 ] {0bc6edc4-65f8-48a1-8936-0cca2da87804} executeQuery: Poco::Exception. Code: 1000, e.code() = 439, mysqlxx::BadQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) while executing query: 'SELECT `key` FROM `test_iimmzbkq`.`foo`' (127.0.0.1:9004) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42816) (comment: 02479_mysql_connect_to_self.sql) (in query: SELECT count() FROM mysql('127.0.0.1:9004', currentDatabase(), foo, 'default', '[HIDDEN]', SETTINGS connect_timeout = 100, connection_wait_timeout = 100)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./src/Common/mysqlxx/./mysqlxx/Exception.h:41: mysqlxx::Query::executeImpl() @ 0x000000001e54abb9 2. ./build_docker/./src/Common/mysqlxx/Query.cpp:74: mysqlxx::Query::use() @ 0x000000001e54afa1 3. ./build_docker/./src/Processors/Sources/MySQLSource.cpp:54: DB::MySQLSource::Connection::Connection(mysqlxx::Pool::Entry const&, String const&) @ 0x000000001a7ac614 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MySQLWithFailoverSource::onStart() @ 0x000000001a7adb3a 5. ./build_docker/./src/Processors/Sources/MySQLSource.cpp:129: DB::MySQLWithFailoverSource::generate() @ 0x000000001a7aec1a 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:08.861658 [ 23792 ] {0bc6edc4-65f8-48a1-8936-0cca2da87804} TCPHandler: Code: 1000. DB::Exception: mysqlxx::BadQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) while executing query: 'SELECT `key` FROM `test_iimmzbkq`.`foo`' (127.0.0.1:9004). (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&, int) @ 0x000000001e594d03 1. ./src/Common/mysqlxx/./mysqlxx/Exception.h:41: mysqlxx::Query::executeImpl() @ 0x000000001e54abb9 2. ./build_docker/./src/Common/mysqlxx/Query.cpp:74: mysqlxx::Query::use() @ 0x000000001e54afa1 3. ./build_docker/./src/Processors/Sources/MySQLSource.cpp:54: DB::MySQLSource::Connection::Connection(mysqlxx::Pool::Entry const&, String const&) @ 0x000000001a7ac614 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MySQLWithFailoverSource::onStart() @ 0x000000001a7adb3a 5. ./build_docker/./src/Processors/Sources/MySQLSource.cpp:129: DB::MySQLWithFailoverSource::generate() @ 0x000000001a7aec1a 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:08.892191 [ 3849 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:08.936992 [ 24824 ] {e8319204-47d7-4cc9-a2a3-a326cda010c6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42948) (comment: 02479_mysql_connect_to_self.sql) (in query: DROP DATABASE IF EXISTS test_iimmzbkq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:08.937762 [ 24824 ] {e8319204-47d7-4cc9-a2a3-a326cda010c6} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:09.111580 [ 2976 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:09.649144 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:09.687091 [ 2941 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:09.726337 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:10.112972 [ 2923 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:10.526237 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:10.612183 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:10.687782 [ 2898 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:11.113935 [ 2888 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:11.393083 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:11.468427 [ 3268 ] {} e65115cb-5e1c-42d4-89fb-c8843de9708c::all_0_4_12_5 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001adc1ddc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193778a4 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:11.469027 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e65115cb-5e1c-42d4-89fb-c8843de9708c::all_0_4_12_5}: Code: 999. Coordination::Exception: Fault injected (before part commit). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001adc1ddc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193778a4 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:11.480924 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:11.688520 [ 2890 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:12.114916 [ 2880 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:12.228862 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:12.357389 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:12.689436 [ 2834 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:13.106218 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:13.106303 [ 2855 ] {} test_9.table_with_unsuccessful_commits (e65115cb-5e1c-42d4-89fb-c8843de9708c): The local set of parts of table test_9.table_with_unsuccessful_commits (e65115cb-5e1c-42d4-89fb-c8843de9708c) doesn't look like the set of parts in ZooKeeper: 30.00 rows of 350.00 total rows in filesystem are suspicious. There are 1 uncovered unexpected parts with 30 rows (1 of them is not just-written with 30 rows), 0 missing parts (with 0 blocks), 0 covered unexpected parts (with 0 rows). 2025.06.12 19:07:13.115727 [ 2854 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:13.234561 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:13.271456 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {efc9ab92-e475-4973-9a01-6dd22a9c9450::202506_104_114_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:13.419220 [ 3283 ] {} e65115cb-5e1c-42d4-89fb-c8843de9708c::all_0_4_12_5 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001adc1ddc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193778a4 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:13.419684 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e65115cb-5e1c-42d4-89fb-c8843de9708c::all_0_4_12_5}: Code: 999. Coordination::Exception: Fault injected (before part commit). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001adc1ddc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193778a4 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:13.690385 [ 2793 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:13.967902 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:14.111078 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:14.116499 [ 2754 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:14.649709 [ 24824 ] {61805cc9-7e67-415a-9310-088cb7a39279} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43990) (comment: 01067_join_null.sql) (in query: SELECT id FROM ( SELECT 1 AS id UNION ALL SELECT NULL UNION ALL SELECT NULL ) js1 ALL FULL OUTER JOIN ( SELECT 1 AS id UNION ALL SELECT NULL UNION ALL SELECT NULL ) js2 USING (id) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:14.651619 [ 24824 ] {61805cc9-7e67-415a-9310-088cb7a39279} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:14.691437 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:14.796266 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:15.025392 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:15.117169 [ 2749 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:15.624819 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:15.692166 [ 2738 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:15.871070 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:16.117896 [ 2728 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:16.454939 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:16.692967 [ 2723 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:16.710797 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:17.169576 [ 2715 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:17.271970 [ 24824 ] {63678baf-c408-44b3-b6d6-5ec17a343fe1} executeQuery: Code: 36. DB::Exception: Disk `s3_disk` already exists and is described by the config. It is impossible to redefine it.: While processing disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_9`, disk = s3_disk). (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44038) (comment: 02808_custom_disk_with_user_defined_name.sh) (in query: CREATE TABLE test (`a` Int32, `b` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_9`, disk = s3_disk), index_granularity = 40803, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 67, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 240371180, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25217388, merge_max_block_size = 21651, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9728593003, 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 = 13530400, concurrent_part_removal_threshold = 91, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 13196, primary_key_compress_block_size = 33053), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000019c68e80 5. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000019c6a2fc 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000019c6a02d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019c69399 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c22aa4 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e39b02 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:17.273270 [ 24824 ] {63678baf-c408-44b3-b6d6-5ec17a343fe1} TCPHandler: Code: 36. DB::Exception: Disk `s3_disk` already exists and is described by the config. It is impossible to redefine it.: While processing disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_9`, disk = s3_disk). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000019c68e80 5. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000019c6a2fc 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000019c6a02d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019c69399 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c22aa4 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e39b02 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:17.294035 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:17.554296 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:17.693750 [ 2701 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:18.120938 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:18.170392 [ 2685 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:18.385156 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:18.694943 [ 3172 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:18.955884 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:19.171406 [ 3166 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:19.238346 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:19.695911 [ 3157 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:19.790574 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:20.079639 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:20.172269 [ 3131 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:20.695333 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:20.696992 [ 3124 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:20.948073 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:21.173056 [ 3108 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:21.426290 [ 24824 ] {adf5740a-4c7c-49d7-b074-c7002fd56cab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44172) (comment: 00078_string_concat.sql) (in query: select concat(toFixedString('a', 1), 'b', toFixedString('c', 1)) == '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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:21.427077 [ 24824 ] {adf5740a-4c7c-49d7-b074-c7002fd56cab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:21.531916 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:21.697858 [ 3104 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:21.778047 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:22.173799 [ 3095 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:22.374318 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:22.698953 [ 3082 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:22.712276 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:23.174676 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:23.228542 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:23.564603 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:23.699738 [ 3053 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:24.067519 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:24.119551 [ 3460 ] {b354ecc5-b0bc-45ba-a780-460ec70291d0} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_9.t_json_async_insert FORMAT JSONAsObject' with query id e0db9a7c-83ac-4b46-9434-77c19ef760fe. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.06.12 19:07:24.175494 [ 3019 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:24.324363 [ 24824 ] {e0db9a7c-83ac-4b46-9434-77c19ef760fe} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:38954) (comment: 02421_new_type_json_async_insert.sh) (in query: INSERT INTO t_json_async_insert 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeTextImpl(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000016faefaf 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016faf7f8 6. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:181: DB::JSONAsObjectRowInputFormat::readJSONObject(DB::IColumn&) @ 0x000000001a46ab0f 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:53: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001a4697ea 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000001a38ba64 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000001a2fd09a 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:0: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000001a2fcc8a 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550228 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:24.325359 [ 24824 ] {e0db9a7c-83ac-4b46-9434-77c19ef760fe} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeTextImpl(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000016faefaf 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016faf7f8 6. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:181: DB::JSONAsObjectRowInputFormat::readJSONObject(DB::IColumn&) @ 0x000000001a46ab0f 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:53: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001a4697ea 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000001a38ba64 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000001a2fd09a 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:0: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000001a2fcc8a 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550228 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:24.424953 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:24.700634 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:24.917863 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:25.176187 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:25.344659 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:25.673151 [ 5636 ] {36076be6-5245-4f2e-81b7-adf95e66db28} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_9.t_json_async_insert FORMAT JSONAsObject' with query id 5cec25f9-054e-4e2c-a3dc-8493713b64df. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.06.12 19:07:25.674757 [ 24824 ] {5cec25f9-054e-4e2c-a3dc-8493713b64df} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39036) (comment: 02421_new_type_json_async_insert.sh) (in query: INSERT INTO t_json_async_insert 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeTextImpl(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000016faefaf 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016faf7f8 6. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:181: DB::JSONAsObjectRowInputFormat::readJSONObject(DB::IColumn&) @ 0x000000001a46ab0f 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:53: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001a4697ea 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000001a38ba64 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000001a2fd09a 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:0: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000001a2fcc8a 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550228 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:25.676071 [ 24824 ] {5cec25f9-054e-4e2c-a3dc-8493713b64df} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeTextImpl(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000016faefaf 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000016faf7f8 6. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:181: DB::JSONAsObjectRowInputFormat::readJSONObject(DB::IColumn&) @ 0x000000001a46ab0f 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:53: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001a4697ea 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000001a38ba64 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a2fe835 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2ce2b5 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000001a2fd09a 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:0: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000001a2fcc8a 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000017550228 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000017553b07 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:25.701557 [ 3015 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:25.752339 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:26.176829 [ 2972 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:26.179500 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:26.588104 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:26.702222 [ 2976 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:27.023610 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:27.204111 [ 2960 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:27.439305 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:27.702947 [ 2937 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:27.908410 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:28.205029 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:28.267915 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:28.703704 [ 2923 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:28.746009 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:29.113711 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:29.205856 [ 2917 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:29.612956 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:29.704475 [ 2922 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:29.936013 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:30.207013 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:30.524919 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:30.705481 [ 2867 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:30.781207 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:31.207901 [ 2871 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:31.402273 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:31.601371 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:31.706667 [ 2853 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:32.208707 [ 2875 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:32.271194 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:32.423681 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:32.707334 [ 2844 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:33.183111 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:33.209407 [ 2827 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:33.363712 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:33.708014 [ 2791 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:34.125276 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:34.198359 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:34.210146 [ 2808 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:34.708739 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:34.972450 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:35.034151 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:35.211111 [ 2792 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:35.709563 [ 2788 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:35.836948 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:35.884958 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:36.211986 [ 2851 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:36.687939 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:36.710336 [ 2745 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:36.712783 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:37.212708 [ 2978 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:37.531421 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:37.549578 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:37.711769 [ 2728 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:38.213564 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:38.380933 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:38.387712 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:38.713558 [ 2711 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:39.214331 [ 2687 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:39.222634 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:39.239845 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:39.714382 [ 2683 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:40.087638 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:40.118739 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:40.242278 [ 3176 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:40.715385 [ 3195 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:40.968156 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:40.992150 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:41.243082 [ 3174 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:41.716273 [ 3154 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:41.800412 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:41.846420 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:42.243917 [ 3148 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:42.633879 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:42.669684 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:42.717210 [ 3127 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:43.244735 [ 3119 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:43.486169 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:43.506656 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:43.718678 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:44.245489 [ 3091 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:44.320617 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:44.430251 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:44.719522 [ 3082 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:45.182142 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:45.246176 [ 3077 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:45.290113 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:45.720163 [ 3058 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:46.080538 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:46.125407 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:46.247161 [ 3038 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:46.720920 [ 3197 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:46.908535 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:46.960295 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:47.247886 [ 3055 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:47.721594 [ 3008 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:47.733452 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:47.803816 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:48.248553 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:48.583144 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:48.635534 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:48.722452 [ 2998 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:49.250172 [ 2988 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:49.418306 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:49.545539 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:49.723731 [ 2982 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:49.736600 [ 3849 ] {b1b220dc-c3f2-465a-9d0f-db202cb89730} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(ColumnLowCardinality): While executing RawBLOBRowOutputFormat. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43050) (comment: 02429_low_cardinality_trash.sh) (in query: SELECT rand64(1) % 10 AS k, groupArray(toString(64 - floor(log2(rand64(2) + 1))))::Array(LowCardinality(String)) FROM numbers(100) GROUP BY k FORMAT RawBLOB), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000018ab53dd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:0: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001a600645 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001a30332e 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:32: DB::IRowOutputFormat::consume(DB::Chunk) @ 0x000000001a302e8f 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::IOutputFormat::work() @ 0x000000001a3013fe 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821b8bc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 16. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:49.738234 [ 3849 ] {b1b220dc-c3f2-465a-9d0f-db202cb89730} DynamicQueryHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(ColumnLowCardinality): While executing RawBLOBRowOutputFormat. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000018ab53dd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:0: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001a600645 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001a30332e 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:32: DB::IRowOutputFormat::consume(DB::Chunk) @ 0x000000001a302e8f 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::IOutputFormat::work() @ 0x000000001a3013fe 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821b8bc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 16. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:50.251298 [ 2962 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:50.336959 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:50.432599 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:50.724389 [ 2957 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:51.252149 [ 2935 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:51.281338 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:51.461114 [ 29533 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:51.629347 [ 24824 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:46954, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1d81fa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:51.629927 [ 4083 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:46968, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1d81fa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:51.631924 [ 29516 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:46978, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1d81fa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:51.695287 [ 29521 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:46984, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1d81fa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:51.730905 [ 2937 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:51.851241 [ 29538 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:46998, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1d81fa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:51.869543 [ 29577 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:47016, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1d81fa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:52.188632 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:52.252996 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:52.364761 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:52.734066 [ 2985 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:53.010965 [ 23952 ] {96d8bd22-049d-44a9-a4fe-b209a2a17a29} executeQuery: Code: 57. DB::Exception: Table test_9.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46032) (comment: 00875_join_right_nulls.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:53.011840 [ 23952 ] {96d8bd22-049d-44a9-a4fe-b209a2a17a29} TCPHandler: Code: 57. DB::Exception: Table test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:53.023310 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:53.210861 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:53.253813 [ 2921 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:53.735029 [ 2915 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:53.936153 [ 23952 ] {1b8ee6bc-e91d-462d-a465-84678ed869a2} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'LowCardinality(Nullable(String))'), 'String'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46054) (comment: 00974_low_cardinality_cast.sql) (in query: SELECT CAST(CAST(Null AS LowCardinality(Nullable(String))) AS 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&) 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) @ 0x0000000007a2ca63 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:07:53.937008 [ 23952 ] {1b8ee6bc-e91d-462d-a465-84678ed869a2} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'LowCardinality(Nullable(String))'), 'String'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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&) 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) @ 0x0000000007a2ca63 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:07:53.962261 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:54.120585 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:54.208693 [ 23952 ] {1c549e85-aa29-4c75-82f2-3048c6e944a6} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(String)'), 'String'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46054) (comment: 00974_low_cardinality_cast.sql) (in query: SELECT CAST(CAST(Null AS Nullable(String)) AS 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x0000000007a2be72 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:07:54.211450 [ 23952 ] {1c549e85-aa29-4c75-82f2-3048c6e944a6} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(String)'), 'String'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x0000000007a2be72 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007762447 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007653464 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087122b7 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:07:54.254954 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:54.735763 [ 3152 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:54.868745 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:54.965034 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:55.255710 [ 2852 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:55.736509 [ 2846 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:55.776138 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:55.801413 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:56.256396 [ 2839 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:56.499819 [ 23952 ] {70cefb94-b685-4d06-8919-580b82b746ab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46114) (comment: 02842_truncate_database.sql) (in query: SELECT * FROM dest_view_merge_tree ORDER BY x 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:07:56.501670 [ 23952 ] {70cefb94-b685-4d06-8919-580b82b746ab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:07:56.601704 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:56.649472 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:56.737405 [ 2832 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:57.257142 [ 2791 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:57.472337 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:57.524191 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:57.738250 [ 2786 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:58.257884 [ 2797 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:58.345475 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:58.373600 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:58.739011 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:58.872287 [ 23952 ] {4909acb2-e4fc-4d00-a95b-c55fa8288b6f} executeQuery: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46182) (comment: 02371_analyzer_join_cross.sql) (in query: SELECT id FROM test_table_join_1, test_table_join_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000174d6c8c 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751b525 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bff0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000001751e3f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174ab47a 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499e4e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:58.873248 [ 23952 ] {4909acb2-e4fc-4d00-a95b-c55fa8288b6f} TCPHandler: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1, test_table_join_2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000174d6c8c 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751b525 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bff0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000001751e3f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174ab47a 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499e4e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:58.880396 [ 23952 ] {3e81b076-eef4-43d9-90b6-8816d7a26c7a} executeQuery: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46182) (comment: 02371_analyzer_join_cross.sql) (in query: SELECT value FROM test_table_join_1, test_table_join_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000174d6c8c 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751b525 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bff0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000001751e3f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174ab47a 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499e4e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:58.880994 [ 23952 ] {3e81b076-eef4-43d9-90b6-8816d7a26c7a} TCPHandler: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1, test_table_join_2. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000174d6c8c 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751b525 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001751bff0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000001751e3f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174ab47a 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499e4e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:59.188782 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:59.228535 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:59.258896 [ 2777 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:59.739861 [ 2756 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:07:59.923577 [ 23952 ] {18a87409-fc94-4a32-9d45-9ccff4e73ef6} executeQuery: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46254) (comment: 02004_invalid_partition_mutation_stuck.sql) (in query: ALTER TABLE rep_data MATERIALIZE INDEX idx IN PARTITION ID 'NO_SUCH_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000019b9955b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e2d85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIdsAffectedByCommands(DB::MutationCommands const&, std::shared_ptr) const @ 0x0000000019a156b2 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6051: DB::StorageReplicatedMergeTree::allocateBlockNumbersInAffectedPartitions(DB::MutationCommands const&, std::shared_ptr, std::shared_ptr const&) const @ 0x00000000193fec1a 8. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019433ab3 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:07:59.924729 [ 23952 ] {18a87409-fc94-4a32-9d45-9ccff4e73ef6} TCPHandler: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000019b9955b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e2d85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIdsAffectedByCommands(DB::MutationCommands const&, std::shared_ptr) const @ 0x0000000019a156b2 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6051: DB::StorageReplicatedMergeTree::allocateBlockNumbersInAffectedPartitions(DB::MutationCommands const&, std::shared_ptr, std::shared_ptr const&) const @ 0x00000000193fec1a 8. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019433ab3 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:00.055156 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:00.206917 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:00.217388 [ 23952 ] {7a8fb52d-9c85-4c23-a874-678cdc01dd4a} executeQuery: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46254) (comment: 02004_invalid_partition_mutation_stuck.sql) (in query: ALTER TABLE data MATERIALIZE INDEX idx IN PARTITION ID 'NO_SUCH_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000019b9955b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e2d85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIdsAffectedByCommands(DB::MutationCommands const&, std::shared_ptr) const @ 0x0000000019a156b2 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b655 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:00.217887 [ 23952 ] {7a8fb52d-9c85-4c23-a874-678cdc01dd4a} TCPHandler: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000019b9955b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000199e2d85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIdsAffectedByCommands(DB::MutationCommands const&, std::shared_ptr) const @ 0x0000000019a156b2 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b655 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:00.259776 [ 2811 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:00.740860 [ 2685 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:00.973746 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:01.047028 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:01.260452 [ 3176 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:01.493211 [ 3849 ] {1cab972c-1817-400f-bacf-923d4c865310} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43092) (comment: 02515_aggregate_functions_statistics.sql) (in query: DROP DATABASE IF EXISTS test_y42v74fj ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:01.494641 [ 3849 ] {1cab972c-1817-400f-bacf-923d4c865310} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:01.742012 [ 3157 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:01.803161 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:01.925206 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:02.181558 [ 25390 ] {3c8f01e6-1a8c-4a1c-be90-e4917fd1c144} executeQuery: Code: 57. DB::Exception: Table test_hi0xjaxa.test_bloom_filter_index already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46356) (comment: 01414_bloom_filter_index_with_const_column.sql) (in query: CREATE TABLE test_bloom_filter_index (`uint8` UInt8, `uint16` UInt16, `index_column` UInt64, INDEX test1 index_column TYPE bloom_filter GRANULARITY 1) ENGINE = MergeTree PARTITION BY tuple() ORDER BY tuple() SETTINGS index_granularity = 10782, min_bytes_for_wide_part = 434365895, 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 = 9117375, compact_parts_max_bytes_to_buffer = 60453320, compact_parts_max_granules_to_buffer = 198, compact_parts_merge_max_bytes_to_prefetch_part = 20669389, merge_max_block_size = 1781, old_parts_lifetime = 224., 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 = 29135097, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 58862, primary_key_compress_block_size = 37368), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:02.183362 [ 25390 ] {3c8f01e6-1a8c-4a1c-be90-e4917fd1c144} TCPHandler: Code: 57. DB::Exception: Table test_hi0xjaxa.test_bloom_filter_index already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:02.251266 [ 23927 ] {ae791737-0f60-47fc-aa3c-c5e362589bd3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50172) (comment: 01414_bloom_filter_index_with_const_column.sql) (in query: DROP DATABASE IF EXISTS test_hi0xjaxa ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:02.251924 [ 23927 ] {ae791737-0f60-47fc-aa3c-c5e362589bd3} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:02.261117 [ 3124 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:02.657816 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:02.743042 [ 3126 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:02.760004 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:03.262014 [ 3113 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:03.486617 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:03.609088 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:03.743832 [ 3067 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:04.262980 [ 3187 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:04.392733 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:04.439126 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:04.744627 [ 3076 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:05.263867 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:05.281905 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:05.313816 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:05.745299 [ 2995 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:06.121686 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:06.136884 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:06.264656 [ 3012 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:06.746043 [ 2881 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:06.957788 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:06.963623 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:07.265373 [ 2962 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:07.730151 [ 23952 ] {61f54eeb-aca9-48fe-a0c3-b61099989e43} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53908) (comment: 02494_query_cache_min_query_runs.sql) (in query: SELECT 1 SETTINGS use_query_cache = true, query_cache_min_query_runs = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:07.730837 [ 23952 ] {61f54eeb-aca9-48fe-a0c3-b61099989e43} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:07.746953 [ 2947 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:07.780415 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:07.783836 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:08.266249 [ 2937 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:08.319164 [ 23952 ] {cda5d3da-e6ee-4bee-9dc9-0316b356c72d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int64, UInt32)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('42', 'Variant(UInt32, Int64)'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53948) (comment: 02999_variant_suspicious_types.sql) (in query: select 42::Variant(UInt32, Int64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.319756 [ 23952 ] {cda5d3da-e6ee-4bee-9dc9-0316b356c72d} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int64, UInt32)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('42', 'Variant(UInt32, Int64)'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.325903 [ 23952 ] {2b86bcb0-b453-4124-aa36-261ab91f685e} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Array(Int64), Array(UInt32))' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[42]', 'Variant(Array(UInt32), Array(Int64))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53948) (comment: 02999_variant_suspicious_types.sql) (in query: select [42]::Variant(Array(UInt32), Array(Int64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.326310 [ 23952 ] {2b86bcb0-b453-4124-aa36-261ab91f685e} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Array(Int64), Array(UInt32))' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[42]', 'Variant(Array(UInt32), Array(Int64))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.330870 [ 23952 ] {f8047120-3fc9-414f-ad6f-b1d57b134ee8} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(LowCardinality(String), String)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('Hello', 'Variant(String, LowCardinality(String))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53948) (comment: 02999_variant_suspicious_types.sql) (in query: select 'Hello'::Variant(String, LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.331278 [ 23952 ] {f8047120-3fc9-414f-ad6f-b1d57b134ee8} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(LowCardinality(String), String)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('Hello', 'Variant(String, LowCardinality(String))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.421402 [ 23952 ] {3a1aecd9-e2e5-4fdb-8f73-7adb3b199521} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Tuple(Int64, String), Tuple(UInt32, String))' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('(1, \'Hello\')', 'Variant(Tuple(UInt32, String), Tuple(Int64, String))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53948) (comment: 02999_variant_suspicious_types.sql) (in query: select (1, 'Hello')::Variant(Tuple(UInt32, String), Tuple(Int64, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.422048 [ 23952 ] {3a1aecd9-e2e5-4fdb-8f73-7adb3b199521} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Tuple(Int64, String), Tuple(UInt32, String))' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('(1, \'Hello\')', 'Variant(Tuple(UInt32, String), Tuple(Int64, String))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.429341 [ 23952 ] {95b6f74a-815b-4be8-af13-64e4c693ae63} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Map(UInt64, Int64), Map(UInt64, UInt32))' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map(42, 42), 'Variant(Map(UInt64, UInt32), Map(UInt64, Int64))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53948) (comment: 02999_variant_suspicious_types.sql) (in query: select map(42, 42)::Variant(Map(UInt64, UInt32), Map(UInt64, Int64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.429831 [ 23952 ] {95b6f74a-815b-4be8-af13-64e4c693ae63} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Map(UInt64, Int64), Map(UInt64, UInt32))' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map(42, 42), 'Variant(Map(UInt64, UInt32), Map(UInt64, Int64))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000001826df52 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 31. __tsan_thread_start_func @ 0x000000000758af2f 2025.06.12 19:08:08.613701 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:08.642876 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:08.747687 [ 2931 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:09.267097 [ 2914 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:09.461040 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:09.495494 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:09.748392 [ 2917 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:10.119646 [ 23952 ] {23883713-8168-4ffb-88f4-f814e26669d2} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_6. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54006) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_6 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.120693 [ 23952 ] {23883713-8168-4ffb-88f4-f814e26669d2} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.147166 [ 23467 ] {2964a5b4-b4c7-4ac0-a8d0-b9a4b40d781b} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54030) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.148220 [ 23467 ] {2964a5b4-b4c7-4ac0-a8d0-b9a4b40d781b} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.267798 [ 2895 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:10.387787 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.459793 [ 24824 ] {a536729a-fbbf-4919-983a-e391b8ccdd11} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_test?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54032) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_3 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.462020 [ 24824 ] {a536729a-fbbf-4919-983a-e391b8ccdd11} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_test?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.462543 [ 29516 ] {31fac6ea-5f86-4bc9-a5b7-4081c6091600} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54052) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_3 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.463725 [ 29516 ] {31fac6ea-5f86-4bc9-a5b7-4081c6091600} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.484463 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.558572 [ 23467 ] {50379e3d-b887-46e1-9262-9bb09a48382d} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_9 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54088) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_9 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.575276 [ 23467 ] {50379e3d-b887-46e1-9262-9bb09a48382d} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_9 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.578277 [ 29538 ] {4c10dc41-1a26-43ed-9957-9891b42d2168} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_4 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54106) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_4 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.579474 [ 29538 ] {4c10dc41-1a26-43ed-9957-9891b42d2168} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_4 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.580040 [ 29577 ] {8559a0c3-cf7f-4fdb-ae2d-5850a43739d7} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54118) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_7 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.581558 [ 29577 ] {8559a0c3-cf7f-4fdb-ae2d-5850a43739d7} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.642962 [ 30753 ] {220ab617-6043-47b1-876a-386a531b525b} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_4 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54186) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_4 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.644374 [ 30753 ] {220ab617-6043-47b1-876a-386a531b525b} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_4 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.658956 [ 30752 ] {e9d809c4-706f-4f18-b14a-ac5e8773d99f} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_5. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54176) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_5 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.659748 [ 30752 ] {e9d809c4-706f-4f18-b14a-ac5e8773d99f} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.661269 [ 30749 ] {566b4128-369a-4002-a1f2-8a6663f9f74a} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_9 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54174) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_9 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.662125 [ 30749 ] {566b4128-369a-4002-a1f2-8a6663f9f74a} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_9 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.750849 [ 2828 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:10.758876 [ 29521 ] {ea9b53da-e996-4189-9e08-527215573b20} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54060) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_6 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:10.759811 [ 29521 ] {ea9b53da-e996-4189-9e08-527215573b20} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.009738 [ 24824 ] {6ce1d250-03ab-4954-8611-d58f338a3eb3} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54252) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_7 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.010822 [ 24824 ] {6ce1d250-03ab-4954-8611-d58f338a3eb3} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.169793 [ 4083 ] {4436477b-aba1-46d2-a45b-bb85394cad8f} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_9 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54278) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_9 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.171728 [ 4083 ] {4436477b-aba1-46d2-a45b-bb85394cad8f} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_9 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.268555 [ 2692 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:11.449944 [ 29577 ] {a8bcda59-f809-4e88-a307-62e76efd82b0} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54376) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_7 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.453563 [ 29577 ] {a8bcda59-f809-4e88-a307-62e76efd82b0} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.503647 [ 29579 ] {d66d953a-5cc3-45b0-acb4-7d604ed93560} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54416) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_7 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.506755 [ 29579 ] {d66d953a-5cc3-45b0-acb4-7d604ed93560} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.537547 [ 30739 ] {7315364f-c775-4526-9216-510980000724} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54444) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_7 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.538371 [ 30739 ] {7315364f-c775-4526-9216-510980000724} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.539493 [ 30752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.574727 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.618118 [ 30752 ] {091f107e-6bd3-4b64-b0d4-197db254aa06} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_5 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54488) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.619234 [ 30752 ] {091f107e-6bd3-4b64-b0d4-197db254aa06} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_5 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.698636 [ 29516 ] {a627afa1-f36d-4165-b029-e9ce6e9154e2} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54514) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_2 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.700448 [ 29516 ] {a627afa1-f36d-4165-b029-e9ce6e9154e2} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:11.751576 [ 2703 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:12.272843 [ 2886 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:12.377584 [ 29538 ] {b7e774af-8b70-439a-9ff4-1cdabe6689fb} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54696) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.378785 [ 29538 ] {b7e774af-8b70-439a-9ff4-1cdabe6689fb} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.413247 [ 30746 ] {25b37131-d232-4831-9617-8daacdc7be36} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54774) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_3 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.414031 [ 30746 ] {25b37131-d232-4831-9617-8daacdc7be36} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.538235 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.538242 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.699888 [ 30749 ] {61e15eb1-3d4c-486b-abdf-f594f6eeea24} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54858) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_7 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.701019 [ 30749 ] {61e15eb1-3d4c-486b-abdf-f594f6eeea24} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.734765 [ 2935 ] {} test_9.alter_table_0 (1c0e8abe-8910-4036-bde8-9b618447fadc): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:12.762368 [ 3135 ] {} test_9.alter_table_9 (3e652a7b-c893-40dd-8dd2-03aadd5a16b7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:12.766154 [ 3098 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:12.797898 [ 30980 ] {f5dc653c-6241-4725-8290-d4ffdadaab9f} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54886) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_0 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:12.799531 [ 30980 ] {f5dc653c-6241-4725-8290-d4ffdadaab9f} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.128834 [ 23792 ] {a8bcdef8-c8cf-4b29-b2aa-b563e2782733} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54926) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.129874 [ 23792 ] {a8bcdef8-c8cf-4b29-b2aa-b563e2782733} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.197318 [ 29577 ] {fc6f0b28-e254-49c9-9947-6c2ef557153f} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54676) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_0 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.197348 [ 29580 ] {55b0f930-0bd0-4557-9044-3bbafa14472f} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54842) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.197362 [ 30749 ] {afff0e0b-0142-4421-81de-2fb757ead22b} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54916) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_0 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.199854 [ 30749 ] {afff0e0b-0142-4421-81de-2fb757ead22b} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.199876 [ 29580 ] {55b0f930-0bd0-4557-9044-3bbafa14472f} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.219508 [ 29577 ] {fc6f0b28-e254-49c9-9947-6c2ef557153f} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.229671 [ 23467 ] {3b7c7044-c9ff-46a5-9732-2fc57088eaf4} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_0 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54928) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_0 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.231388 [ 23467 ] {3b7c7044-c9ff-46a5-9732-2fc57088eaf4} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_0 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.333723 [ 2732 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.335793 [ 30980 ] {1dee4946-96a4-4d29-bc30-03c77b8acc03} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_0. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54966) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_0 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.336733 [ 30980 ] {1dee4946-96a4-4d29-bc30-03c77b8acc03} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_0. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.400302 [ 23792 ] {411c7ab8-b09f-4835-b8d3-cef5033a9863} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_0 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54988) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_0 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.401272 [ 23792 ] {411c7ab8-b09f-4835-b8d3-cef5033a9863} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_0 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.421454 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.457178 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.747119 [ 3279 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::4_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.748728 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::4_0_0_0_1}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.768546 [ 3268 ] {} 58c09933-6ab7-4fe3-a215-4b917cca493b::4_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.770559 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {58c09933-6ab7-4fe3-a215-4b917cca493b::4_0_0_0_1}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.771359 [ 2904 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.811214 [ 3276 ] {} ec546210-b24b-4ecc-8703-e01b644de28d::4_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.813256 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ec546210-b24b-4ecc-8703-e01b644de28d::4_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.888266 [ 2799 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.888531 [ 2738 ] {} test_9.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.888755 [ 2735 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.888935 [ 2800 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:13.950244 [ 23952 ] {8041de8e-d5ab-4049-a06b-ba97924b954a} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0 already exists. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54790) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: CREATE TABLE alter_table_0 (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table', 'r_0') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, replicated_max_mutations_in_one_entry = 529, index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 74, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 339609341, compact_parts_max_granules_to_buffer = 178, compact_parts_merge_max_bytes_to_prefetch_part = 19694758, merge_max_block_size = 2235, 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, concurrent_part_removal_threshold = 68, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 8850, primary_key_compress_block_size = 81252), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x0000000019348406 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:560: 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) @ 0x0000000019335f05 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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&) @ 0x0000000019e40427 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b183 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191ba866 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.968938 [ 23952 ] {8041de8e-d5ab-4049-a06b-ba97924b954a} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0 already exists. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x0000000019348406 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:560: 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) @ 0x0000000019335f05 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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&) @ 0x0000000019e40427 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b183 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191ba866 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.974163 [ 30752 ] {cf6cdb3a-77e6-416b-afa5-29ae0d6fe957} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55092) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:13.979290 [ 30752 ] {cf6cdb3a-77e6-416b-afa5-29ae0d6fe957} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.048032 [ 3277 ] {} ec546210-b24b-4ecc-8703-e01b644de28d::4_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:14.048841 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ec546210-b24b-4ecc-8703-e01b644de28d::4_0_0_0_1}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:14.137911 [ 4083 ] {ed3c6897-cd4f-40af-85cb-683c6479a48c} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_3. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55100) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_3 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.139433 [ 4083 ] {ed3c6897-cd4f-40af-85cb-683c6479a48c} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_3. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.152273 [ 29533 ] {e40ba339-cd30-49fe-a0d2-b3a12811e502} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54668) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_9 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.159976 [ 29533 ] {e40ba339-cd30-49fe-a0d2-b3a12811e502} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.176597 [ 29579 ] {a3cebdc1-3d9a-4cfb-8e4d-26c815a14374} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54536) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_9 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.190805 [ 29579 ] {a3cebdc1-3d9a-4cfb-8e4d-26c815a14374} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.242270 [ 29533 ] {24853233-ad7e-4c41-b67c-ebfc27536750} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55150) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_7 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.243358 [ 29533 ] {24853233-ad7e-4c41-b67c-ebfc27536750} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.280091 [ 30752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.335014 [ 3026 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:14.339975 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.520423 [ 30981 ] {c4f23ae7-9ae9-4304-af29-e1ea515f85c5} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55256) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_7 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.521287 [ 30981 ] {c4f23ae7-9ae9-4304-af29-e1ea515f85c5} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.772053 [ 2884 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:14.788780 [ 23792 ] {168adb1a-bc6c-42aa-8e68-3f0dd08dab80} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_9 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55322) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_9 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.795705 [ 23792 ] {168adb1a-bc6c-42aa-8e68-3f0dd08dab80} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_9 does not exist. Maybe you meant test_9.alter_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.852644 [ 30980 ] {55489258-a628-46f1-b6f0-7fc8e4266416} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_9. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55354) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:14.892080 [ 30980 ] {55489258-a628-46f1-b6f0-7fc8e4266416} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_9. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:15.067185 [ 2799 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.096378 [ 2790 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.100411 [ 2776 ] {} test_9.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.158978 [ 31183 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:15.180994 [ 30752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:15.203310 [ 2804 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.337090 [ 2817 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.682367 [ 3282 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column e): (while reading from part /var/lib/clickhouse/store/777/7779edca-b815-4b88-adca-6384948e7a52/-2_0_0_0/ in table test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52) located on disk default of type local, from mark 0 with max_rows_to_read = 5002): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d205 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d47e 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:144: 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 @ 0x0000000016f5eecb 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 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>>&) @ 0x0000000019be070e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.687687 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column e): (while reading from part /var/lib/clickhouse/store/777/7779edca-b815-4b88-adca-6384948e7a52/-2_0_0_0/ in table test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52) located on disk default of type local, from mark 0 with max_rows_to_read = 5002): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d205 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d47e 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:144: 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 @ 0x0000000016f5eecb 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 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>>&) @ 0x0000000019be070e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.755522 [ 2735 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): Log pointer of source replica r_4 changed while we loading queue nodes. Will retry. 2025.06.12 19:08:15.774611 [ 2744 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.798184 [ 31234 ] {9a7b04da-c42b-4d60-91c6-7fd23c783340} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_9. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55516) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:15.804374 [ 31234 ] {9a7b04da-c42b-4d60-91c6-7fd23c783340} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_9. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:15.812987 [ 3277 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.813452 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:15.957534 [ 31263 ] {249ce286-ea51-48f0-9cc4-4a80e2c6df62} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55582) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:15.959915 [ 31263 ] {249ce286-ea51-48f0-9cc4-4a80e2c6df62} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:15.988707 [ 31234 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:16.064522 [ 31183 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:16.222949 [ 3281 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_12 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.223622 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.342605 [ 3160 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.359224 [ 2799 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.359363 [ 2855 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #16, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.359451 [ 2833 ] {} test_9.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #16, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.359874 [ 2831 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #16, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.377604 [ 2771 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #17, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.496662 [ 3268 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_12 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.497665 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_12}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.758701 [ 3269 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_0_0_0_9 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.760330 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_0_0_0_9}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.768053 [ 3279 ] {} 58c09933-6ab7-4fe3-a215-4b917cca493b::-1_0_0_0_12 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.768578 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {58c09933-6ab7-4fe3-a215-4b917cca493b::-1_0_0_0_12}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.775522 [ 3061 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.831220 [ 3281 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_12 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=785). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:213: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000017e9eeaa 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000019c9a1ab 11. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000019c99315 12. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000019c9270a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:16.927844 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=785). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:213: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000017e9eeaa 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000019c9a1ab 11. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000019c99315 12. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000019c9270a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:17.013786 [ 31258 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:17.035951 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:17.132973 [ 3283 ] {} 95069f1a-d02a-471f-ad3f-145d87409ee1::-2_0_0_0_9 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:17.133796 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {95069f1a-d02a-471f-ad3f-145d87409ee1::-2_0_0_0_9}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:17.345821 [ 3004 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:17.776532 [ 3118 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:17.881891 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:17.892280 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:18.346775 [ 3152 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:18.616507 [ 31266 ] {932ef43f-465f-45c4-b63f-6f64c8158205} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56104) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:18.617499 [ 31266 ] {932ef43f-465f-45c4-b63f-6f64c8158205} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:18.768426 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:18.773723 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:18.780743 [ 2826 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:19.347832 [ 2820 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:19.386766 [ 29521 ] {0cc255fb-f050-4c3a-aabf-ab1d3205046a} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56270) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:19.387722 [ 29521 ] {0cc255fb-f050-4c3a-aabf-ab1d3205046a} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:19.498232 [ 31263 ] {9d93e55a-e23d-47d0-bed2-a25317c2922d} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001772ef13 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:313: std::__shared_ptr_emplace>::__on_zero_shared() @ 0x00000000177005e8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoiningTransform::~JoiningTransform() @ 0x000000001a69d63b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:313: std::__shared_ptr_emplace>::__on_zero_shared() @ 0x0000000016df82c9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: std::__shared_ptr_emplace, std::allocator>>, std::allocator, std::allocator>>>>::__on_zero_shared() @ 0x0000000016dd4611 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::QueryPipeline::~QueryPipeline() @ 0x0000000016dd8641 13. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:698: DB::QueryPipeline::reset() @ 0x0000000016de015b 14. ./build_docker/./src/QueryPipeline/BlockIO.cpp:60: DB::BlockIO::onFinish() @ 0x0000000016dc4408 15. ./build_docker/./src/Server/TCPHandler.cpp:579: DB::TCPHandler::runImpl() @ 0x000000001a1d8fbf 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:19.615716 [ 31263 ] {ca06849e-be8a-4fbe-995b-a6dad6fccf37} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001772ef13 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:313: std::__shared_ptr_emplace>::__on_zero_shared() @ 0x00000000177005e8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoiningTransform::~JoiningTransform() @ 0x000000001a69d63b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:313: std::__shared_ptr_emplace>::__on_zero_shared() @ 0x0000000016df82c9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: std::__shared_ptr_emplace, std::allocator>>, std::allocator, std::allocator>>>>::__on_zero_shared() @ 0x0000000016dd4611 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::QueryPipeline::~QueryPipeline() @ 0x0000000016dd8641 13. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:698: DB::QueryPipeline::reset() @ 0x0000000016de015b 14. ./build_docker/./src/QueryPipeline/BlockIO.cpp:60: DB::BlockIO::onFinish() @ 0x0000000016dc4408 15. ./build_docker/./src/Server/TCPHandler.cpp:579: DB::TCPHandler::runImpl() @ 0x000000001a1d8fbf 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:19.636019 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:19.637789 [ 30748 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:19.781467 [ 2702 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:19.905645 [ 3273 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_29 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:19.906757 [ 3273 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_29}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:19.962109 [ 2924 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:20.348764 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:20.356430 [ 31263 ] {9e10ee27-e4ed-4c24-91fe-22cb61167d8f} 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=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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001772e7b8 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e119da 9. ./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&) @ 0x0000000017df0110 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&) @ 0x0000000017de0b12 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:20.367590 [ 31263 ] {9e10ee27-e4ed-4c24-91fe-22cb61167d8f} 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.10057.altinitytest (altinity build)) (from [::1]:55794) (comment: 00172_hits_joins.gen.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY LEFT JOIN ( SELECT (CounterID % 100000) AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0 ) USING CounterID WHERE hits = 0 OR visits = 0 ORDER BY hits + visits * 10 DESC, CounterID ASC LIMIT 20 SETTINGS any_join_distinct_right_table_keys = 1, joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001772e7b8 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e119da 9. ./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&) @ 0x0000000017df0110 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&) @ 0x0000000017de0b12 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:20.374629 [ 31263 ] {9e10ee27-e4ed-4c24-91fe-22cb61167d8f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001772e7b8 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e119da 9. ./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&) @ 0x0000000017df0110 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&) @ 0x0000000017de0b12 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc18cb 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dbd063 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dba27b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821621e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:20.507913 [ 30752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:20.509428 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:20.582583 [ 31263 ] {71912e27-aa41-458e-8ac9-1480285e1226} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56500) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:20.686763 [ 31263 ] {71912e27-aa41-458e-8ac9-1480285e1226} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:20.782343 [ 2762 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:20.813024 [ 24824 ] {ecfa34eb-99b8-4596-820a-db56aba432a0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=800). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56440) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM system.parts 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:20.817164 [ 24824 ] {ecfa34eb-99b8-4596-820a-db56aba432a0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=800). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:20.832791 [ 3163 ] {} test_9.alter_table_1 (95069f1a-d02a-471f-ad3f-145d87409ee1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:20.963014 [ 2701 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:20.963923 [ 31255 ] {dfbe78b4-38b0-47f8-9a45-c3404781ed84} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56214) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_1 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.057394 [ 31255 ] {dfbe78b4-38b0-47f8-9a45-c3404781ed84} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.071487 [ 31183 ] {d60af880-68b2-41cd-86ea-b4abc3996953} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55970) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_1 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.119992 [ 31183 ] {d60af880-68b2-41cd-86ea-b4abc3996953} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.349608 [ 3057 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:21.373633 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.476933 [ 31230 ] {8c8f58d9-c9ff-4ee2-bd8c-fb05fa6a17a6} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56664) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.583169 [ 31230 ] {8c8f58d9-c9ff-4ee2-bd8c-fb05fa6a17a6} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.597986 [ 31263 ] {5f8ff25e-49ab-47dc-a52b-eb5b9b613c45} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56698) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_7 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.602110 [ 31263 ] {5f8ff25e-49ab-47dc-a52b-eb5b9b613c45} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_7 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.619331 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.785951 [ 31241 ] {b12cba04-143b-4149-9e84-18ac41d2affa} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56772) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.788099 [ 31241 ] {b12cba04-143b-4149-9e84-18ac41d2affa} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.794937 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:21.798577 [ 30981 ] {073f7c39-853b-4795-bc74-6554c787c148} 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.10057.altinitytest (altinity build)) (from [::1]:56548) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT sum(cityHash64(*)) FROM (SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID) SETTINGS optimize_aggregation_in_order = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:21.802265 [ 30981 ] {073f7c39-853b-4795-bc74-6554c787c148} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:22.021252 [ 3091 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:22.024801 [ 31241 ] {8c9a916b-aebd-49e7-adb6-3204e271030f} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46378) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_2 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:22.025752 [ 31241 ] {8c9a916b-aebd-49e7-adb6-3204e271030f} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:22.237958 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:22.350854 [ 2842 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:22.582420 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:22.693305 [ 3042 ] {} test_9.alter_table_9 (ec0c1781-0bf5-469b-a28a-3d4787544d76): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:22.771429 [ 31692 ] {75c0f3fd-e9c8-4d64-beb2-66be61521bdb} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46530) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:22.772861 [ 31692 ] {75c0f3fd-e9c8-4d64-beb2-66be61521bdb} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:22.796985 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:22.804242 [ 3129 ] {} test_9.alter_table_6 (58c09933-6ab7-4fe3-a215-4b917cca493b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:22.942550 [ 3276 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_39 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:22.947188 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_39}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.032164 [ 3049 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.117410 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:23.179671 [ 3277 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_39 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.185807 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_39}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.244814 [ 3274 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_40 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.256668 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_40}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.307466 [ 2818 ] {} test_9.alter_table_6 (58c09933-6ab7-4fe3-a215-4b917cca493b): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cd4d1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.338565 [ 3122 ] {} test_9.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.353118 [ 2693 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.380650 [ 3278 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-1_15_15_0_40 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.382898 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-1_15_15_0_40}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.505482 [ 3271 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_40 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.508959 [ 3271 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_40}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.509321 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:23.525203 [ 30749 ] {c20214dc-3a7e-4ae1-970d-bb156db8719c} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55088) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_6 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8813: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x000000001945d4bb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fc446 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:23.525651 [ 31255 ] {5b4ce8bf-736f-4cfe-8ae4-73793126b733} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46690) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:23.529202 [ 31255 ] {5b4ce8bf-736f-4cfe-8ae4-73793126b733} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:23.550745 [ 30749 ] {c20214dc-3a7e-4ae1-970d-bb156db8719c} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8813: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x000000001945d4bb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fc446 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:23.617220 [ 3273 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-1_15_15_0_40 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.627578 [ 3273 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-1_15_15_0_40}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.686035 [ 3166 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering -6_23_23_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:23.801628 [ 3130 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.852937 [ 3270 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_40 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/parts/-1_15_15_0_40. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.857981 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_40}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/parts/-1_15_15_0_40. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.887244 [ 3280 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-1_15_15_0_40 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:23.894973 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-1_15_15_0_40}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.032101 [ 31258 ] {b2b7e787-74ed-4313-8aac-a07024383f0d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=801). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46730) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM system.parts 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.032947 [ 2903 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.049932 [ 31258 ] {b2b7e787-74ed-4313-8aac-a07024383f0d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=801). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.111871 [ 3278 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-1_15_15_0_40 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.181653 [ 31692 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.186582 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-1_15_15_0_40}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.300231 [ 31693 ] {f72bcee3-a4f5-4900-bb5c-4bacfaeb787a} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46822) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.302790 [ 31693 ] {f72bcee3-a4f5-4900-bb5c-4bacfaeb787a} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.323861 [ 30748 ] {325bb4f3-828e-40b0-8e1a-68a71798c0fd} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46794) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.329018 [ 30748 ] {325bb4f3-828e-40b0-8e1a-68a71798c0fd} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.338099 [ 3268 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.342101 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_41}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.354968 [ 3036 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.385700 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.556038 [ 31183 ] {89129a25-82bf-4521-8e81-4f0484462d43} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46394) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_8 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.566172 [ 2904 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.571435 [ 31183 ] {89129a25-82bf-4521-8e81-4f0484462d43} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:24.714673 [ 3122 ] {} test_9.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.740074 [ 3275 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.751235 [ 3282 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.755318 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_0_0_0_41}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.767465 [ 3275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_0_0_0_41}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.804206 [ 2876 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.825478 [ 3269 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.908398 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-2_0_0_0_41}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.911316 [ 3274 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_48 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-1_0_0_0_48. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.911891 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_48}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-1_0_0_0_48. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.916908 [ 3180 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Log pointer of source replica r_4 changed while we loading queue nodes. Will retry. 2025.06.12 19:08:24.958974 [ 3271 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_48 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.965918 [ 3271 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_48}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.976040 [ 3272 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.981684 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_41}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.982826 [ 3276 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_48 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #6, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-1_0_0_0_48. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.984577 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_48}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #6, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-1_0_0_0_48. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:24.994339 [ 3142 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::run(): Code: 999. Coordination::Exception: Coordination error: No node, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:58: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce413 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreePartCheckThread::searchForMissingPartOnOtherReplicas(String const&) const @ 0x0000000019d625d2 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:492: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c7d8 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.033287 [ 23792 ] {a37c3bed-ee4e-4673-8398-00a98a9e97f6} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46998) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_2 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:25.039753 [ 3190 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #13, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.055928 [ 2734 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.064722 [ 2801 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #13, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.100021 [ 23792 ] {a37c3bed-ee4e-4673-8398-00a98a9e97f6} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:25.252295 [ 31691 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:25.296387 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:25.356643 [ 3195 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.555016 [ 3278 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_41 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.557640 [ 3277 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.560287 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-2_0_0_0_41}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.561361 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-2_0_0_0_41}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.571335 [ 3124 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.593518 [ 3275 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.596141 [ 3275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_0_0_0_41}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.610416 [ 3142 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering -6_23_23_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:25.691155 [ 3276 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-3_0_0_0_39 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.696288 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-3_0_0_0_39}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.740980 [ 3281 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_48 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.741851 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_48}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.771822 [ 23792 ] {b94639aa-e605-4fac-b962-a96306c71317} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47152) (comment: 00172_early_constant_folding.sql) (in query: EXPLAIN PIPELINE SELECT count(JavaEnable) FROM test.hits WHERE WatchID = 1 OR Title = 'next' OR URL = 'prev' OR URL = '???' OR 1 SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000017e440a9 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000017e44b63 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4449e 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4484c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018213862 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:25.780092 [ 23792 ] {b94639aa-e605-4fac-b962-a96306c71317} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000017e440a9 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000017e44b63 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4449e 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4484c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018213862 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:25.811045 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.815430 [ 3268 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.818367 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_0_0_0_41}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.828808 [ 3277 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_48 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.831950 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_48}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.899392 [ 3279 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-3_0_0_0_39 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.906526 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-3_0_0_0_39}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.956186 [ 2714 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.974779 [ 3282 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #2, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:25.976460 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_0_0_0_41}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #2, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/parts/-2_0_0_0_41. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.022779 [ 2801 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.035316 [ 3122 ] {} test_9.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.057004 [ 2770 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.069828 [ 3283 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_0_0_0_41 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.071561 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_0_0_0_41}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.084026 [ 23792 ] {e379f775-ffd0-475b-9c11-9aca6d9997f2} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47212) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_2 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:26.087421 [ 23792 ] {e379f775-ffd0-475b-9c11-9aca6d9997f2} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:26.115485 [ 31690 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:26.172224 [ 31691 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:26.381201 [ 3066 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.387528 [ 23792 ] {3ffa59b8-93c3-4c74-80e1-88dcf52f17a6} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47266) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:26.388574 [ 23792 ] {3ffa59b8-93c3-4c74-80e1-88dcf52f17a6} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:26.533038 [ 3269 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_15_15_0_54 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.534947 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_15_15_0_54}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.549634 [ 3279 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_54 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.578640 [ 2877 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.629821 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_54}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:26.815706 [ 3067 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.013931 [ 31690 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:27.028428 [ 3270 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_54 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.030556 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_54}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.063433 [ 2818 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.063678 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:27.142616 [ 31230 ] {e1514c44-caeb-41ff-8658-af8edd0f1b5b} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47440) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:27.145184 [ 31230 ] {e1514c44-caeb-41ff-8658-af8edd0f1b5b} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:27.184153 [ 2953 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Log pointer of source replica r_5 changed while we loading queue nodes. Will retry. 2025.06.12 19:08:27.359095 [ 2714 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #30, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.378701 [ 2907 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #30, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.382402 [ 3189 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.465822 [ 2789 ] {} test_9.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #30, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.583095 [ 2898 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.674776 [ 2855 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #30, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.867258 [ 2700 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:27.927685 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:27.955030 [ 31183 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:28.068019 [ 3088 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:28.420221 [ 2866 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:28.483997 [ 3269 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_61 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:28.484764 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_61}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:28.595517 [ 2803 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:28.787920 [ 31693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:28.818555 [ 31694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:28.868165 [ 2792 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:29.071001 [ 3119 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:29.425865 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:29.596427 [ 3007 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:29.607371 [ 3283 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_64 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:29.608117 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_64}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:29.655758 [ 31695 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:29.706433 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:29.868968 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:29.888552 [ 31263 ] {6e0fd668-cda2-462c-9f57-1cd44bab217f} 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.10057.altinitytest (altinity build)) (from [::1]:47888) (comment: 00072_compare_date_and_string_index.sql) (in query: SELECT count() FROM test.hits WHERE EventDate = toDate('2014-03-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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:29.890248 [ 31263 ] {6e0fd668-cda2-462c-9f57-1cd44bab217f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:30.056215 [ 2770 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering -6_23_23_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:30.077233 [ 2800 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.088446 [ 3276 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_64 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.089270 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_64}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.117021 [ 3270 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_73 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.117856 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_73}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.234752 [ 30748 ] {105bef76-c6e2-473d-b5b5-ccd3beafcfd0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47980) (comment: 00162_mmap_compression_none.sql) (in query: INSERT INTO hits_none SELECT Title FROM test.hits SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:30.263501 [ 30748 ] {105bef76-c6e2-473d-b5b5-ccd3beafcfd0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:30.401825 [ 23792 ] {a53e495d-6a7e-4df2-a0d4-d8be96e9032a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33040) (comment: 00162_mmap_compression_none.sql) (in query: DROP DATABASE IF EXISTS test_1evl2yqg ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:30.402714 [ 23792 ] {a53e495d-6a7e-4df2-a0d4-d8be96e9032a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.438707 [ 3022 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.448243 [ 17132 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.454371 [ 2787 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.454572 [ 3043 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.462589 [ 2812 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.483271 [ 30753 ] {9efac4b0-38b4-492b-9308-1542e5d5fe84} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_7. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48026) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_7 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:30.499069 [ 30753 ] {9efac4b0-38b4-492b-9308-1542e5d5fe84} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_7. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:30.509644 [ 3280 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_64 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/a99/a991c6ec-26b8-4e79-9287-7cf7432a7148/-1_15_15_0_54/ in table test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148) located on disk default of type local, from mark 0 with max_rows_to_read = 2535): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d5c0b5 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5dad4 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5e04e 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 19. ./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>>&) @ 0x0000000019be070e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.511194 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_64}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/a99/a991c6ec-26b8-4e79-9287-7cf7432a7148/-1_15_15_0_54/ in table test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148) located on disk default of type local, from mark 0 with max_rows_to_read = 2535): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d5c0b5 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5dad4 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5e04e 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 19. ./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>>&) @ 0x0000000019be070e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.533595 [ 3268 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-1_0_0_0_73 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.534168 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-1_0_0_0_73}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.546332 [ 2804 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.546595 [ 2727 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.546643 [ 2841 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.546645 [ 2710 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.547489 [ 2950 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.547696 [ 2712 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.547817 [ 2723 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.548316 [ 2986 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.548590 [ 2791 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.548838 [ 2755 ] {} test_9.alter_table_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.550369 [ 2911 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.550603 [ 2891 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.550431 [ 2782 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.551308 [ 3113 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.551910 [ 3053 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.551866 [ 2715 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:08:30.562937 [ 31183 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:30.570589 [ 2770 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): Cannot commit empty part -6_23_23_0 with error Coordination::Exception: Session expired 2025.06.12 19:08:30.570772 [ 3142 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part -6_23_23_0 with error Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-6_23_23_0 2025.06.12 19:08:30.570804 [ 2770 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -6_23_23_0 instead of lost. Will retry later 2025.06.12 19:08:30.570955 [ 3142 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -6_23_23_0 instead of lost. Will retry later 2025.06.12 19:08:30.578715 [ 3166 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Cannot commit empty part -6_23_23_0 with error Coordination::Exception: Session expired 2025.06.12 19:08:30.578976 [ 3166 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -6_23_23_0 instead of lost. Will retry later 2025.06.12 19:08:30.619734 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:30.623067 [ 3271 ] {7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_64} auto DB::ReplicatedMergeMutateTaskBase::executeImpl()::(anonymous class)::operator()() const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/queue/queue-0000000167. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:556: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add24d5 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:592: DB::ReplicatedMergeTreeQueue::removeProcessedEntry(std::shared_ptr, std::shared_ptr&) @ 0x0000000019d80c0f 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:149: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_0::operator()() const @ 0x0000000019d36c81 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a21 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.619784 [ 2741 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.637068 [ 2745 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cd4d1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.650897 [ 2699 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cd4d1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.811878 [ 31241 ] {3aacc3d3-67bd-402e-bd9d-dce620ebe92f} ~EphemeralLocksInAllPartitions: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/block_numbers/-9/block-0000000070. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, Coordination::RemoveResponse const&) @ 0x000000001adeb39c 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001ae58e98 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::finalize(bool, bool, String const&) @ 0x000000001ae45f0c 7. ./contrib/llvm-project/libcxx/include/string:1499: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae506a0 8. ./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*) @ 0x000000001ae58593 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007f4e69e13ac3 13. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.856393 [ 2747 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.862958 [ 2995 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations/0000000053. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, Coordination::GetResponse const&) @ 0x000000001ade9444 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001ae59258 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::finalize(bool, bool, String const&) @ 0x000000001ae45f0c 7. ./contrib/llvm-project/libcxx/include/string:1499: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae506a0 8. ./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*) @ 0x000000001ae58593 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007f4e69e13ac3 13. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.886772 [ 2995 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.889218 [ 2714 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.890872 [ 3025 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.910724 [ 3072 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.942707 [ 2789 ] {} test_9.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.972951 [ 3142 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.973738 [ 3166 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.974943 [ 2789 ] {} test_9.alter_table_3 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.975193 [ 2747 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.972220 [ 2770 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.986844 [ 3269 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_73 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 12. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.988385 [ 3278 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_73 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 12. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:30.994666 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_73}: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 12. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.002910 [ 3273 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_15_15_0_64 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/parts/-1_15_15_0_64. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001ae6d9dc 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1818: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937082c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 11. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.006700 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_73}: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 12. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.008367 [ 3273 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_15_15_0_64}: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/parts/-1_15_15_0_64. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001ae6d9dc 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1818: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937082c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 11. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.010036 [ 3272 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_73 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/parts/-1_0_0_0_73. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001ae6d9dc 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1818: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937082c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 11. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.012300 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_73}: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/parts/-1_0_0_0_73. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001ae6d9dc 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1818: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937082c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 11. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.036301 [ 2953 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/-5_3_3_0. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/-5_3_3_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1516: DB::StorageReplicatedMergeTree::cloneReplica(String const&, Coordination::Stat, std::shared_ptr&) @ 0x00000000193b9d32 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x00000000193c9a2a 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf7d8 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.027030 [ 2854 ] {} test_9.alter_table_6 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/-7_3_3_0. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/-7_3_3_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1516: DB::StorageReplicatedMergeTree::cloneReplica(String const&, Coordination::Stat, std::shared_ptr&) @ 0x00000000193b9d32 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x00000000193c9a2a 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf7d8 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.052228 [ 3180 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/queue/queue-. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/queue/queue-. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:415: zkutil::ZooKeeper::tryCreate(String const&, String const&, int, String&) @ 0x000000001adcf6c2 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::create(String const&, String const&, int) @ 0x000000001adcf549 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::cloneReplica(String const&, Coordination::Stat, std::shared_ptr&) @ 0x00000000193ba543 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x00000000193c9a2a 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:179: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf7d8 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.086438 [ 3186 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.102877 [ 2717 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.102952 [ 2686 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d824d7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.107265 [ 3192 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cf7ec 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.108035 [ 3192 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cd4d1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.114715 [ 3183 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.146736 [ 3074 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cf7ec 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.146792 [ 3073 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cf7ec 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.139339 [ 3077 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:08:31.148257 [ 3073 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cd4d1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.148428 [ 2686 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.149280 [ 3074 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cd4d1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.180880 [ 3134 ] {} test_9.alter_table_6 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:08:31.199184 [ 2920 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.199234 [ 3171 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.203377 [ 2919 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.204019 [ 2786 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.209872 [ 3268 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_73 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.210984 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_73}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.211984 [ 3269 ] {} 006aff5b-c836-4731-8f2d-8877341baf9a::-1_0_0_0_73 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.212557 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {006aff5b-c836-4731-8f2d-8877341baf9a::-1_0_0_0_73}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.218693 [ 2807 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:08:31.267359 [ 29579 ] {1107c21c-1278-4861-8756-92a09fcb743c} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55278) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001addf544 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac2fb 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fb73e 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.268866 [ 29579 ] {1107c21c-1278-4861-8756-92a09fcb743c} TCPHandler: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001addf544 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac2fb 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fb73e 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.262721 [ 29521 ] {4720f622-fb9f-4139-848b-7df10571d56b} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46836) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001addf544 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac2fb 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fb73e 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.271448 [ 29521 ] {4720f622-fb9f-4139-848b-7df10571d56b} TCPHandler: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001addf544 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac2fb 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fb73e 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.282842 [ 31231 ] {b1fc456a-0b56-4a2f-9aff-1896831f5610} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55502) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeMergeStrategyPicker.cpp:128: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bf61 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d870e6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 11. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fb73e 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.290876 [ 31183 ] {2a7e1504-4663-4f0f-9267-b5304aeee42c} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48096) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194339d2 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.290867 [ 31269 ] {c79f6954-4b55-42ab-b14d-a8131ba29471} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48104) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194339d2 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.296583 [ 31183 ] {2a7e1504-4663-4f0f-9267-b5304aeee42c} TCPHandler: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194339d2 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.296967 [ 31231 ] {b1fc456a-0b56-4a2f-9aff-1896831f5610} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeMergeStrategyPicker.cpp:128: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bf61 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d870e6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 11. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fb73e 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.298269 [ 31269 ] {c79f6954-4b55-42ab-b14d-a8131ba29471} TCPHandler: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194339d2 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.298817 [ 31008 ] {1cbf1f93-c4f8-4da5-959c-34b9b4c04dd7} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55066) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 12. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fc446 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 14. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.315446 [ 31008 ] {1cbf1f93-c4f8-4da5-959c-34b9b4c04dd7} TCPHandler: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 12. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000193fc446 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193fa32c 14. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.335307 [ 23792 ] {73ca2a8c-d1b8-44b4-ad98-b870e369282f} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48180) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_3 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.335956 [ 31691 ] {1278ec61-ad22-4bd2-b05e-f1c413c26ae5} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_14/replicas/s1|r1. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33036) (comment: 00072_compare_date_and_string_index.sql) (in query: DROP DATABASE IF EXISTS test_0d9ohxyx ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:556: zkutil::ZooKeeper::tryRemoveRecursive(String const&) @ 0x000000001addb5e7 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::drop(std::shared_ptr) @ 0x0000000017106712 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:613: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017692ab2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.336943 [ 23792 ] {73ca2a8c-d1b8-44b4-ad98-b870e369282f} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.339475 [ 31691 ] {1278ec61-ad22-4bd2-b05e-f1c413c26ae5} DynamicQueryHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_14/replicas/s1|r1. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:556: zkutil::ZooKeeper::tryRemoveRecursive(String const&) @ 0x000000001addb5e7 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::drop(std::shared_ptr) @ 0x0000000017106712 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:613: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017692ab2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001821af79 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.394611 [ 3298 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4522: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b0031 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.394720 [ 3304 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a2628 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.394883 [ 3295 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193af85f 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.395160 [ 3307 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4522: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b0031 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.394728 [ 3296 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4522: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b0031 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.394650 [ 3299 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4522: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b0031 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.400313 [ 3294 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b04ab 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.403028 [ 3300 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b04ab 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.403236 [ 3301 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b04ab 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.405477 [ 3297 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001ae6f388 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193779b0 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.406124 [ 3303 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b04ab 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.447900 [ 2969 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.449015 [ 3292 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/parts/9_47_47_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001ae6d9dc 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1818: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937082c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 18. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.449880 [ 3302 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/parts/7_42_42_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001ae6d9dc 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1818: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937082c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 18. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.450622 [ 3306 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/-6_40_40_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001ae6d9dc 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1818: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937082c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 18. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.476337 [ 2818 ] {} test_9.alter_table_8 (ec546210-b24b-4ecc-8703-e01b644de28d): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.476801 [ 2706 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.476387 [ 2714 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.490961 [ 2706 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.492556 [ 2714 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.551476 [ 3305 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 21. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.552145 [ 3293 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 21. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.567119 [ 23792 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.620394 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.654711 [ 3280 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_64 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 14. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.655515 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_64}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 14. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.670326 [ 31269 ] {8f55afe1-b60c-4318-9c01-4c1d2f26cc90} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48216) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_5 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.679646 [ 31269 ] {8f55afe1-b60c-4318-9c01-4c1d2f26cc90} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.784390 [ 31694 ] {9a17f119-c616-4e06-a254-b71ef33abbe6} executeQuery: Code: 57. DB::Exception: Table test_9.alter_table_0 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48262) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: CREATE TABLE alter_table_0 (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table', 'r_0') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, replicated_max_mutations_in_one_entry = 376, index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 74, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 339609341, compact_parts_max_granules_to_buffer = 178, compact_parts_merge_max_bytes_to_prefetch_part = 19694758, merge_max_block_size = 2235, 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, concurrent_part_removal_threshold = 68, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 8850, primary_key_compress_block_size = 81252), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.785848 [ 31694 ] {9a17f119-c616-4e06-a254-b71ef33abbe6} TCPHandler: Code: 57. DB::Exception: Table test_9.alter_table_0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.817842 [ 30752 ] {e0c97017-221e-4e80-bbc5-b287573b5b6e} executeQuery: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47708) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_9 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./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 @ 0x0000000019e030a9 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.822899 [ 30752 ] {e0c97017-221e-4e80-bbc5-b287573b5b6e} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./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 @ 0x0000000019e030a9 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.902992 [ 31255 ] {72f7e68b-eb69-4692-b4b2-c5388036372c} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47626) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_3 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.918597 [ 31255 ] {72f7e68b-eb69-4692-b4b2-c5388036372c} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.932155 [ 31691 ] {67011100-360b-41ac-9170-bbbb2e74370c} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59762) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_0 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.935265 [ 31266 ] {3a3fcbb5-5fb5-4e10-8752-41ac081fa845} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46984) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_3 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:31.935877 [ 2983 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:31.967402 [ 31691 ] {67011100-360b-41ac-9170-bbbb2e74370c} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.000354 [ 31266 ] {3a3fcbb5-5fb5-4e10-8752-41ac081fa845} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.064871 [ 24824 ] {9588f1e5-87e9-4103-8010-e056dfef23b0} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59800) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.065964 [ 31689 ] {9edc001b-64bd-49c3-9d09-c0fce8570072} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59780) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_5 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.078977 [ 24824 ] {9588f1e5-87e9-4103-8010-e056dfef23b0} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_8. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.087261 [ 31694 ] {f12779af-f2fc-4e6a-a4f5-9353bb51c4d5} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59764) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.088328 [ 31694 ] {f12779af-f2fc-4e6a-a4f5-9353bb51c4d5} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.098359 [ 23927 ] {bb084e44-610d-4ab6-94e0-2096bb57693b} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_8 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59806) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.105440 [ 23927 ] {bb084e44-610d-4ab6-94e0-2096bb57693b} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_8 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.140098 [ 31689 ] {9edc001b-64bd-49c3-9d09-c0fce8570072} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.265457 [ 23927 ] {43fbcdc3-4afa-40ab-897b-00cf12e1ff90} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_8 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59842) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_8 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.266760 [ 23927 ] {43fbcdc3-4afa-40ab-897b-00cf12e1ff90} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_8 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.449321 [ 2917 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:32.450722 [ 31693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.488952 [ 31263 ] {4896804e-743e-4fa3-bac9-e2a7b1190466} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59840) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.492597 [ 31693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.492913 [ 31263 ] {4896804e-743e-4fa3-bac9-e2a7b1190466} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.643814 [ 2958 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): Log pointer of source replica r_5 changed while we loading queue nodes. Will retry. 2025.06.12 19:08:32.680510 [ 31258 ] {5176b183-bcde-4565-8b45-3855f71b2773} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59982) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.682036 [ 31258 ] {5176b183-bcde-4565-8b45-3855f71b2773} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.712878 [ 31183 ] {741c63b3-ab87-40d3-b937-aa8bf032400c} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59986) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_2 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.714080 [ 31183 ] {741c63b3-ab87-40d3-b937-aa8bf032400c} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.846975 [ 31183 ] {e16be106-2081-49e8-8d67-0e57837c8ee5} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60012) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_2 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.917690 [ 31183 ] {e16be106-2081-49e8-8d67-0e57837c8ee5} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:32.974669 [ 2975 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:33.068700 [ 31241 ] {280bf3dc-b67c-4d9a-99d2-c7cfea429812} executeQuery: Code: 57. DB::Exception: Table test_l9wn4j2q.ordinary_distinct already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59788) (comment: 00174_distinct_in_order.sql) (in query: CREATE TABLE ordinary_distinct (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 704012778, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 104, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 25891178, compact_parts_max_granules_to_buffer = 139, compact_parts_merge_max_bytes_to_prefetch_part = 15829172, merge_max_block_size = 12843, old_parts_lifetime = 352., 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 = 1, concurrent_part_removal_threshold = 10, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 23042, primary_key_compress_block_size = 13036), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.070642 [ 23952 ] {57b74a06-8546-4e58-bb12-42b075cc1d1b} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60066) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.071997 [ 23952 ] {57b74a06-8546-4e58-bb12-42b075cc1d1b} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.090928 [ 31241 ] {280bf3dc-b67c-4d9a-99d2-c7cfea429812} TCPHandler: Code: 57. DB::Exception: Table test_l9wn4j2q.ordinary_distinct already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.122660 [ 31183 ] {e85e1a87-7812-46da-9fbd-444d7e492959} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60068) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_5 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.123891 [ 31183 ] {e85e1a87-7812-46da-9fbd-444d7e492959} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000194353cb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.290076 [ 31231 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.352134 [ 31008 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.403443 [ 23952 ] {1ccbf473-259c-4b2d-a6b0-96fd1b61ff95} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60144) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.404562 [ 23952 ] {1ccbf473-259c-4b2d-a6b0-96fd1b61ff95} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.450047 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:33.569334 [ 31694 ] {576e7528-8fdb-4af8-ab43-5d97ad6986bc} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59846) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_6 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.589227 [ 31694 ] {576e7528-8fdb-4af8-ab43-5d97ad6986bc} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.681248 [ 23952 ] {1da60433-6f9a-4cad-94b5-5185c1d46b45} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60182) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_9 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.683151 [ 23952 ] {1da60433-6f9a-4cad-94b5-5185c1d46b45} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:33.738828 [ 3010 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 7_31_31_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:33.849731 [ 2880 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:33.903677 [ 17246 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 19:08:33.911557 [ 17246 ] {} DatabaseCatalog: Cannot drop table test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:33.913556 [ 3112 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 7_31_31_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:33.922698 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 7_31_31_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:33.976837 [ 3072 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.164911 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.185342 [ 3281 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_73 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.185990 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_73}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.208293 [ 31693 ] {535c8720-7e2a-4ed4-8536-66f803d15ae4} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60302) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.214744 [ 31693 ] {535c8720-7e2a-4ed4-8536-66f803d15ae4} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.222014 [ 30752 ] {2e7ba862-05bf-4c7b-a80f-afb708e78c72} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60298) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.230973 [ 30752 ] {2e7ba862-05bf-4c7b-a80f-afb708e78c72} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.281352 [ 31231 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.283106 [ 30981 ] {e3614acd-fd81-47cd-9672-f73f68edc95d} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60076) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_6 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.298406 [ 30981 ] {e3614acd-fd81-47cd-9672-f73f68edc95d} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:824: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000019e052ad 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.311673 [ 3283 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_64 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.315952 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_64}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.422299 [ 31269 ] {369175ab-b04f-42f1-a8ec-7e28c6c4eeac} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60382) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_2 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.427632 [ 31269 ] {369175ab-b04f-42f1-a8ec-7e28c6c4eeac} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.451213 [ 3050 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.557776 [ 3269 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_18_18_0_87 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.559384 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_18_18_0_87}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.573024 [ 3278 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_18_18_0_87 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.574382 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_18_18_0_87}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.811807 [ 2915 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #60, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1597: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001add5abd 7. ./contrib/llvm-project/libcxx/include/vector:547: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cf3 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.817822 [ 31694 ] {44484f71-edee-42b2-b4e1-315c6af3ac84} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_3. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60464) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_3 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.818791 [ 31694 ] {44484f71-edee-42b2-b4e1-315c6af3ac84} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_3. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.870035 [ 3279 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_18_18_0_87 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.872272 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_18_18_0_87}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:34.962900 [ 31694 ] {002cf6ca-e427-4193-ba29-c6bb36c45748} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60504) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.965820 [ 31694 ] {002cf6ca-e427-4193-ba29-c6bb36c45748} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:34.980922 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:35.017858 [ 31241 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:35.040318 [ 3274 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_64 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:35.046627 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_64}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:35.124941 [ 3270 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_89 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:35.125819 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_15_15_0_89}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:35.160252 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:35.458780 [ 3181 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:35.542955 [ 3277 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_95 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:35.543542 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_95}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:35.864323 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.031915 [ 2833 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:36.203280 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.338645 [ 31268 ] {c17bbe7e-9106-458e-a30b-3bc5311a63c4} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60872) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.340207 [ 31268 ] {c17bbe7e-9106-458e-a30b-3bc5311a63c4} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.370075 [ 23792 ] {ac1d0a4f-521e-4e8e-a2fd-588f3b70c8b2} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60874) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_2 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.371380 [ 23792 ] {ac1d0a4f-521e-4e8e-a2fd-588f3b70c8b2} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007651cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c216f1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.460431 [ 3132 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:36.727329 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.907497 [ 31268 ] {2e4136b2-ca90-4299-a5b1-5fdb0ff778e9} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32770) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_6 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.910197 [ 31268 ] {2e4136b2-ca90-4299-a5b1-5fdb0ff778e9} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5800: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000193f9877 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827c5d8 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:36.995859 [ 31255 ] {e93d421f-a296-478c-8e0a-fd8371144eba} executeQuery: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60262) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_8 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./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 @ 0x0000000019e030a9 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.033291 [ 3274 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_102 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.033939 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_102}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.050914 [ 31255 ] {e93d421f-a296-478c-8e0a-fd8371144eba} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./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 @ 0x0000000019e030a9 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.057384 [ 3278 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_102 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column e): (while reading from part /var/lib/clickhouse/store/a99/a991c6ec-26b8-4e79-9287-7cf7432a7148/-1_0_0_0_95/ in table test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148) located on disk default of type local, from mark 0 with max_rows_to_read = 2502): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d205 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d47e 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:144: 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 @ 0x0000000016f5eecb 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 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>>&) @ 0x0000000019be070e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.058183 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_102}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column e): (while reading from part /var/lib/clickhouse/store/a99/a991c6ec-26b8-4e79-9287-7cf7432a7148/-1_0_0_0_95/ in table test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148) located on disk default of type local, from mark 0 with max_rows_to_read = 2502): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d205 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d47e 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:144: 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 @ 0x0000000016f5eecb 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 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>>&) @ 0x0000000019be070e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.063058 [ 2971 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.081501 [ 29579 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.138861 [ 24824 ] {94060160-19ae-40d0-b54f-ae6ec60c2b9e} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32808) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_3 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.147975 [ 24824 ] {94060160-19ae-40d0-b54f-ae6ec60c2b9e} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.161971 [ 31231 ] {f21fdcff-25d3-49fb-95a0-d4e30b88c340} executeQuery: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60418) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_9 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./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 @ 0x0000000019e030a9 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.174356 [ 31231 ] {f21fdcff-25d3-49fb-95a0-d4e30b88c340} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./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 @ 0x0000000019e030a9 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.360028 [ 3277 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_102 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.365723 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_102}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e23f1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.461318 [ 2984 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.540743 [ 30753 ] {f8f1a4dd-5295-428f-9cb1-dc57d1345871} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32946) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_3 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.542201 [ 30753 ] {f8f1a4dd-5295-428f-9cb1-dc57d1345871} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447ba 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.579381 [ 31693 ] {e288bce8-da8b-40bc-8a21-991fec9fd6c9} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32948) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_2 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.580255 [ 31693 ] {e288bce8-da8b-40bc-8a21-991fec9fd6c9} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_2 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.648503 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:37.823795 [ 3271 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_18_18_0_105 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.824324 [ 3271 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_18_18_0_105}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:37.941793 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:38.071213 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:38.226263 [ 31266 ] {718adea3-3ee9-4393-8661-a9bb092f197f} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33104) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_3 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:38.228575 [ 31266 ] {718adea3-3ee9-4393-8661-a9bb092f197f} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:38.484892 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:38.502264 [ 2854 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:38.774638 [ 31263 ] {a4be8373-8327-4013-b3f6-181511577e18} executeQuery: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33232) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: OPTIMIZE TABLE alter_table_3 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:38.775621 [ 31263 ] {a4be8373-8327-4013-b3f6-181511577e18} TCPHandler: Code: 60. DB::Exception: Table test_9.alter_table_3 does not exist. Maybe you meant test_9.alter_table_0?. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000007717fd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017139355 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000001827bb47 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:38.816519 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:38.869608 [ 6448 ] {} test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.12 19:08:38.886341 [ 6448 ] {} DatabaseCatalog: Cannot drop table test_9.alter_table_3 (006aff5b-c836-4731-8f2d-8877341baf9a). Will retry later.: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199cdbdd 9. ./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>*) @ 0x00000000199cb387 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199d34f9 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1213: DB::StorageReplicatedMergeTree::drop() @ 0x000000001935fd7b 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001769f60d 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176aa664 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e0558 15. ./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()() @ 0x00000000160e045e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101fb475 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e168d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.073298 [ 3027 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.129194 [ 3268 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_110 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.129879 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_110}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.199254 [ 3276 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_110 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.200357 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_0_0_110}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.240887 [ 3277 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_110 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.241451 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_0_0_110}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.335499 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:39.503250 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.688009 [ 31690 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:39.766854 [ 31694 ] {36dcd222-c268-4e97-ab50-92a87c19b8c2} executeQuery: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1. (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32962) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_1 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./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 @ 0x0000000019e030a9 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:39.829916 [ 30753 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:33322, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1d81fa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.843587 [ 31183 ] {0c1d1d55-7101-44a5-a114-405c450388f1} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33380). (NETWORK_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33380) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM system.parts 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000001a1ed1a3 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e6608 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:39.845986 [ 31183 ] {0c1d1d55-7101-44a5-a114-405c450388f1} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33380). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f84e7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e7adc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9339 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:39.846191 [ 31183 ] {0c1d1d55-7101-44a5-a114-405c450388f1} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33380). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000001a1ed1a3 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e6608 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:39.846720 [ 31183 ] {0c1d1d55-7101-44a5-a114-405c450388f1} TCPHandler: Client has gone away. 2025.06.12 19:08:39.875407 [ 31694 ] {36dcd222-c268-4e97-ab50-92a87c19b8c2} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./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 @ 0x0000000019e030a9 5. ./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 @ 0x0000000019e02cf9 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1118: 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'()&&) @ 0x0000000019e02b11 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000019deda6d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000019ddb9c4 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000019deacac 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:39.876073 [ 31694 ] {36dcd222-c268-4e97-ab50-92a87c19b8c2} TCPHandler: Client has gone away. 2025.06.12 19:08:40.090999 [ 2951 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:40.129881 [ 31690 ] {e3a0a469-00fe-449e-81eb-9c31a50fca62} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33482). (NETWORK_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33482) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM system.parts 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000001a1ed1a3 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e6608 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:40.147676 [ 31690 ] {e3a0a469-00fe-449e-81eb-9c31a50fca62} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33482). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f84e7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e7adc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9339 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:40.147939 [ 31690 ] {e3a0a469-00fe-449e-81eb-9c31a50fca62} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33482). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000001a1ed1a3 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e6608 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:40.148461 [ 31690 ] {e3a0a469-00fe-449e-81eb-9c31a50fca62} TCPHandler: Client has gone away. 2025.06.12 19:08:40.166015 [ 31183 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:40.513364 [ 2824 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:40.529015 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:40.902196 [ 3270 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:40.903351 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_0_0_124}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.005706 [ 3280 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.006399 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_15_15_0_124}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.039060 [ 31183 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:41.092002 [ 2722 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.353261 [ 31183 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:41.514336 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.781110 [ 3282 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_18_18_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.792996 [ 3273 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_18_18_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.793719 [ 3273 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_18_18_0_124}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.822440 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_18_18_0_124}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.898273 [ 3269 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_18_18_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.904767 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_18_18_0_124}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.924627 [ 3272 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_18_18_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=782). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:213: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000017e9eeaa 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000019c9a1ab 11. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000019c99315 12. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000019c9270a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.925350 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_18_18_0_124}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=782). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:213: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000017e9eeaa 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000019c9a1ab 11. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000019c99315 12. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000019c9270a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:41.933700 [ 31183 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.092807 [ 2782 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.120330 [ 31258 ] {209e1a0a-d8d6-42c4-ae0f-49eb90a79a50} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50036) (comment: 00163_column_oriented_formats.sh) (in query: INSERT INTO 00163_column_oriented SELECT ClientEventTime, MobilePhoneModel, ClientIP6 FROM test.hits ORDER BY ClientEventTime, MobilePhoneModel, ClientIP6 LIMIT 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.122914 [ 31258 ] {209e1a0a-d8d6-42c4-ae0f-49eb90a79a50} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./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*) @ 0x000000001a2e044a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.240954 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.316221 [ 31269 ] {afb9265c-dd29-4507-bc02-dfdb5601f699} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:32934). (NETWORK_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32934) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_5 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000001a1eefd7 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9135 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.317502 [ 31269 ] {afb9265c-dd29-4507-bc02-dfdb5601f699} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:32934). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f84e7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e7adc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9339 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.317734 [ 31269 ] {afb9265c-dd29-4507-bc02-dfdb5601f699} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:32934). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000001a1eefd7 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9135 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.318284 [ 31269 ] {afb9265c-dd29-4507-bc02-dfdb5601f699} TCPHandler: Client has gone away. 2025.06.12 19:08:42.369787 [ 31693 ] {cd6291eb-ec58-4cfc-bc59-2ae0d94e07e8} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33052). (NETWORK_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33052) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000001a1eefd7 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9135 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.371158 [ 31693 ] {cd6291eb-ec58-4cfc-bc59-2ae0d94e07e8} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33052). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f84e7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e7adc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9339 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.371408 [ 31693 ] {cd6291eb-ec58-4cfc-bc59-2ae0d94e07e8} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33052). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000001a1eefd7 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9135 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.371798 [ 31693 ] {cd6291eb-ec58-4cfc-bc59-2ae0d94e07e8} TCPHandler: Client has gone away. 2025.06.12 19:08:42.381277 [ 3279 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_47_47_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.385507 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_47_47_0_124}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.397115 [ 3275 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_19_19_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.400062 [ 3275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_19_19_0_124}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.453692 [ 31691 ] {b76b6e97-5bf3-4b37-bfef-d686a77bb220} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:32982, local: [::1]:9000). (NETWORK_ERROR) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32982) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: INSERT INTO alter_table_4 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./build_docker/./src/Server/TCPHandler.cpp:2308: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000001a1ec1a2 8. ./build_docker/./src/Server/TCPHandler.cpp:606: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a1fa863 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:99: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dfde6 10. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1d90cc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.464975 [ 31691 ] {b76b6e97-5bf3-4b37-bfef-d686a77bb220} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:32982). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe3b50 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05b66e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f84e7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e7adc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9339 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007f4e69e13ac3 16. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.465265 [ 31691 ] {b76b6e97-5bf3-4b37-bfef-d686a77bb220} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:32982, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 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&&) @ 0x000000000fbe1f4d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe10dd 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe1754 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a057caf 6. DB::ReadBuffer::next() @ 0x0000000007b3417b 7. ./build_docker/./src/Server/TCPHandler.cpp:2308: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000001a1ec1a2 8. ./build_docker/./src/Server/TCPHandler.cpp:606: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a1fa863 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:99: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dfde6 10. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1d90cc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:42.465752 [ 31691 ] {b76b6e97-5bf3-4b37-bfef-d686a77bb220} TCPHandler: Client has gone away. 2025.06.12 19:08:42.515243 [ 2937 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.533959 [ 3272 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_47_47_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.536455 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_47_47_0_124}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.561522 [ 3280 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_19_19_0_124 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column g): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/-1_19_19_0/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 0 with max_rows_to_read = 4954): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d5c0b5 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5dad4 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5e04e 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 18. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016fc8ee4 19. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:770: DB::SerializationTuple::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 @ 0x00000000170381c8 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 21. ./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>>&) @ 0x0000000019be070e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.564017 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_19_19_0_124}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column g): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/-1_19_19_0/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 0 with max_rows_to_read = 4954): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d5c0b5 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5dad4 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d5e04e 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 18. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016fc8ee4 19. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:770: DB::SerializationTuple::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 @ 0x00000000170381c8 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 21. ./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>>&) @ 0x0000000019be070e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.713654 [ 3018 ] {} test_9.alter_table_6 (c4581507-bd56-4a30-872d-69a6a549bf68): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:42.840085 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:43.089831 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:43.094209 [ 2944 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:43.516152 [ 2935 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:43.681713 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:43.763919 [ 2854 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::run(): Code: 999. Coordination::Exception: Coordination error: No node, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:58: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce413 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreePartCheckThread::searchForMissingPartOnOtherReplicas(String const&) const @ 0x0000000019d625d2 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:492: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c7d8 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:43.764938 [ 3077 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:43.911484 [ 2958 ] {} test_9.alter_table_8 (ReplicatedMergeTreeQueue): Cannot get mutation node 0000000041 (No node), probably it was concurrently removed 2025.06.12 19:08:43.918310 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:43.953093 [ 3280 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_0_0_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:43.999453 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_0_0_0_122}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.052328 [ 3010 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 7_31_31_0 with error Coordination::Exception: Transaction failed (No node): Op #16, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/parts/7_31_31_0 2025.06.12 19:08:44.052513 [ 3010 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 7_31_31_0 instead of lost. Will retry later 2025.06.12 19:08:44.094983 [ 2865 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.181679 [ 3010 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 3_34_34_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:44.289509 [ 3283 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_49_1_124 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.290242 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_49_1_124}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.392748 [ 3171 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_6/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.443253 [ 3268 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_49_1_124 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.443780 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-1_0_49_1_124}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.511262 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:44.517201 [ 2940 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.636569 [ 3277 ] {} d5c3c149-fa7e-4536-98d4-499e10c276c8::-2_10_10_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-2_10_10_0_122. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.643291 [ 3279 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_10_10_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-2_10_10_0_122. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.644282 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d5c3c149-fa7e-4536-98d4-499e10c276c8::-2_10_10_0_122}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-2_10_10_0_122. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.645276 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_10_10_0_122}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-2_10_10_0_122. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.791156 [ 3274 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-2_10_10_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-2_10_10_0_122. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.793734 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-2_10_10_0_122}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-2_10_10_0_122. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.793878 [ 3171 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.795053 [ 3130 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001adc32c4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3b5f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.815795 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:44.819343 [ 3280 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-7_0_51_1_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.820414 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-7_0_51_1_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.929781 [ 2732 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering 3_34_34_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:44.930071 [ 3278 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_10_10_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-2_10_10_0_122. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.932192 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_10_10_0_122}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-2_10_10_0_122. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:0: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000019c90d78 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.947501 [ 3279 ] {} d5c3c149-fa7e-4536-98d4-499e10c276c8::-2_10_10_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.952018 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d5c3c149-fa7e-4536-98d4-499e10c276c8::-2_10_10_0_122}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:44.986749 [ 3131 ] {} test_9.alter_table_7 (ReplicatedMergeTreeQueue): Cannot get mutation node 0000000055 (No node), probably it was concurrently removed 2025.06.12 19:08:45.021588 [ 3271 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_10_10_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.032106 [ 3271 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_10_10_0_122}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.095615 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.120643 [ 3270 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_49_1_124 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-1_0_49_1_124. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.120662 [ 3275 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_49_1_124 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-1_0_49_1_124. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.131874 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_49_1_124}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-1_0_49_1_124. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.133770 [ 3275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-1_0_49_1_124}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_3/parts/-1_0_49_1_124. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000001adf8f86 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3624 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1582: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000001ade3b9f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1991: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019378909 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.172232 [ 3272 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_25_25_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.176609 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_25_25_0_122}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.187985 [ 3274 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_25_25_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.189307 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_25_25_0_122}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.512425 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:45.519264 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.556308 [ 3283 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-1_0_49_1_124 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.573669 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-1_0_49_1_124}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.670645 [ 3281 ] {} d5c3c149-fa7e-4536-98d4-499e10c276c8::-2_25_25_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.672398 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d5c3c149-fa7e-4536-98d4-499e10c276c8::-2_25_25_0_122}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.679396 [ 3282 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_33_33_0_122 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.681031 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::-2_33_33_0_122}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:45.787513 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:46.129637 [ 2903 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:46.252107 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering 1_78_78_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:46.401427 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:46.528107 [ 3137 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:46.575213 [ 2773 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -2_55_55_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:46.630432 [ 2732 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Part 3_34_34_0 is lost forever. 2025.06.12 19:08:46.644541 [ 3112 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Part 7_31_31_0 is lost forever. 2025.06.12 19:08:46.646834 [ 3010 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 3_34_34_0 with error Coordination::Exception: Transaction failed (Node exists): Op #4, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/parts/3_34_34_0 2025.06.12 19:08:46.647033 [ 3010 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 3_34_34_0 instead of lost. Will retry later 2025.06.12 19:08:46.688310 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:46.705102 [ 2995 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001769e9e7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000001769f17c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176aa3a2 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:47.130437 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:47.246181 [ 2712 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_28_28_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:47.248094 [ 3110 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering -2_55_55_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:47.248794 [ 3163 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Cannot commit empty part 7_31_31_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:08:47.248895 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 7_31_31_0 instead of lost. Will retry later 2025.06.12 19:08:47.293830 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:47.528878 [ 2876 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:47.556926 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:47.567713 [ 3112 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_28_28_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:47.575189 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Part 1_78_78_0 is lost forever. 2025.06.12 19:08:47.581241 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part -1_0_49_1_124 covering part -1_15_15_0_89, will not check 2025.06.12 19:08:47.587844 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part -1_0_49_1_124 covering part -1_47_47_0_124, will not check 2025.06.12 19:08:47.674277 [ 2773 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Part -2_55_55_0 is lost forever. 2025.06.12 19:08:47.688962 [ 3274 ] {} test_9.alter_table_9 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_25_25_0 to 122) 2025.06.12 19:08:47.701228 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part -1_0_49_1_124 covering part -1_18_18_0_98, will not check 2025.06.12 19:08:47.709581 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part -1_0_49_1_124 covering part -1_15_15_0_103, will not check 2025.06.12 19:08:47.720271 [ 2917 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering -6_23_23_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:47.722949 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_28_28_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:47.759338 [ 3272 ] {} test_9.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_25_25_0 to 122) 2025.06.12 19:08:47.760058 [ 3272 ] {} test_9.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_33_33_0 to 122) 2025.06.12 19:08:47.766785 [ 3279 ] {} test_9.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_45_45_0 to 122) 2025.06.12 19:08:47.844389 [ 3270 ] {} test_9.alter_table_5 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_33_33_0 to 122) 2025.06.12 19:08:47.848805 [ 3273 ] {} test_9.alter_table_9 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_33_33_0 to 122) 2025.06.12 19:08:47.849246 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part -1_0_49_1_124 covering part -1_18_18_0_105, will not check 2025.06.12 19:08:47.851864 [ 3276 ] {} test_9.alter_table_5 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_45_45_0 to 122) 2025.06.12 19:08:47.858080 [ 3273 ] {} test_9.alter_table_8 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_10_10_0 to 122) 2025.06.12 19:08:47.863801 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part -1_0_49_1_124 covering part -1_15_15_0_119, will not check 2025.06.12 19:08:47.864261 [ 3279 ] {d5c3c149-fa7e-4536-98d4-499e10c276c8::-2_25_25_0_122} d5c3c149-fa7e-4536-98d4-499e10c276c8::-2_25_25_0_122 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (583bf2911f9da262cd5a7d183f881245 vs 56b88edbdcce8631df46707a51d9ebe6), uncompressed hash of compressed files doesn't match (53a747371766d7f4cc03b1e395068f64 vs 80c5da4b031f8f36ba87416aa2fcc102). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.12 19:08:47.875605 [ 3271 ] {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_25_25_0_122} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::-2_25_25_0_122 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (583bf2911f9da262cd5a7d183f881245 vs 56b88edbdcce8631df46707a51d9ebe6), uncompressed hash of compressed files doesn't match (53a747371766d7f4cc03b1e395068f64 vs 80c5da4b031f8f36ba87416aa2fcc102). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.12 19:08:47.904658 [ 2773 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -2_72_72_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:47.956079 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering -1_72_72_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:47.972019 [ 3275 ] {} test_9.alter_table_9 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_45_45_0 to 122) 2025.06.12 19:08:47.974410 [ 3275 ] {} test_9.alter_table_1 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_45_45_0 to 122) 2025.06.12 19:08:48.010264 [ 3110 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part -2_55_55_0 with error DB::Exception: Part -2_55_55_0 already exists on replica r_7 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/parts/-2_55_55_0 2025.06.12 19:08:48.010673 [ 3110 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -2_55_55_0 instead of lost. Will retry later 2025.06.12 19:08:48.073737 [ 3270 ] {ba153c9d-0129-4209-ab37-275e8cf118ba::-2_10_10_0_122} ba153c9d-0129-4209-ab37-275e8cf118ba::-2_10_10_0_122 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (405f8943c602451c0828ab8275539cb0 vs ff633b11380bd9a52ab51217b8e82c0f), uncompressed hash of compressed files doesn't match (c6bf6bab287c094b8cfcbf97dbbf6120 vs d4bff46724cfaa577377ad7e9c9ba58c). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10057.altinitytest (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.12 19:08:48.131241 [ 2899 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:48.157659 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:48.392117 [ 3110 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering -1_52_52_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:48.397450 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:48.438054 [ 3283 ] {} test_9.alter_table_1 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_33_33_0 to 122) 2025.06.12 19:08:48.441138 [ 3270 ] {} test_9.alter_table_4 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_33_33_0 to 122) 2025.06.12 19:08:48.445522 [ 3283 ] {} test_9.alter_table_4 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_45_45_0 to 122) 2025.06.12 19:08:48.529594 [ 3063 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:48.840519 [ 3278 ] {} test_9.alter_table_8 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_45_45_0 to 122) 2025.06.12 19:08:49.027177 [ 31689 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:49.133479 [ 3071 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:49.242215 [ 29579 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:49.535377 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:49.888585 [ 31690 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:50.080693 [ 29579 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:50.134964 [ 2756 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:50.536525 [ 2848 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:50.550379 [ 24824 ] {577a4759-1234-48c8-85cc-79f4fb4c3df4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50388) (comment: 00172_hits_joins.gen.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY INNER JOIN ( SELECT (CounterID % 100000) AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0 ) USING CounterID WHERE hits = 0 OR visits = 0 ORDER BY hits + visits * 10 DESC, CounterID ASC LIMIT 20 SETTINGS any_join_distinct_right_table_keys = 1, joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:50.554289 [ 24824 ] {577a4759-1234-48c8-85cc-79f4fb4c3df4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=773). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:50.785177 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:50.917639 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:51.139984 [ 2885 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:51.537270 [ 2974 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:51.606652 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:51.758880 [ 31690 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:52.058244 [ 3112 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Part 2_28_28_0 is lost forever. 2025.06.12 19:08:52.123266 [ 3163 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Cannot commit empty part 2_28_28_0 with error DB::Exception: Part 2_28_28_0 already exists on replica r_0 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/parts/2_28_28_0 2025.06.12 19:08:52.123368 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 2_28_28_0 instead of lost. Will retry later 2025.06.12 19:08:52.131229 [ 3110 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Part -1_52_52_0 is lost forever. 2025.06.12 19:08:52.143279 [ 2948 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:52.143524 [ 2917 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Part -6_23_23_0 is lost forever. 2025.06.12 19:08:52.151061 [ 2712 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 2_28_28_0 with error DB::Exception: Part 2_28_28_0 already exists on replica r_0 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/parts/2_28_28_0 2025.06.12 19:08:52.151290 [ 2712 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 2_28_28_0 instead of lost. Will retry later 2025.06.12 19:08:52.182199 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_34_34_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:52.185924 [ 3109 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering -1_72_72_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:52.188650 [ 2912 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering -6_31_31_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:52.196851 [ 2712 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering -6_31_31_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:52.207020 [ 3023 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Part -1_72_72_0 is lost forever. 2025.06.12 19:08:52.433380 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:52.538850 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:52.613864 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:52.725322 [ 3109 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part -1_72_72_0 with error DB::Exception: Part -1_72_72_0 already exists on replica r_8 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/parts/-1_72_72_0 2025.06.12 19:08:52.725451 [ 3109 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -1_72_72_0 instead of lost. Will retry later 2025.06.12 19:08:52.795185 [ 2917 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering -9_47_47_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:52.800472 [ 2773 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Part -2_72_72_0 is lost forever. 2025.06.12 19:08:52.836608 [ 2912 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Part -6_31_31_0 is lost forever. 2025.06.12 19:08:52.845263 [ 2712 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part -6_31_31_0 with error Coordination::Exception: Transaction failed (Node exists): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/parts/-6_31_31_0 2025.06.12 19:08:52.845458 [ 2712 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -6_31_31_0 instead of lost. Will retry later 2025.06.12 19:08:52.877535 [ 3109 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering -5_42_42_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:52.996555 [ 2773 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -2_58_58_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:53.144128 [ 3064 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:53.258520 [ 24824 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:53.262560 [ 3019 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering -7_63_63_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:53.263946 [ 2912 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_34_34_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:53.283516 [ 3097 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 6_32_32_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:53.452924 [ 31690 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:53.540513 [ 2853 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:53.835801 [ 24824 ] {7707a599-5ef1-48e2-8cda-89d7a31299c0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54426) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: DROP DATABASE IF EXISTS test_i42gmshr ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:53.837927 [ 24824 ] {7707a599-5ef1-48e2-8cda-89d7a31299c0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:53.847038 [ 31690 ] {c45d9071-aa1d-4774-97e0-5c567bfbc49c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54440) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: DROP DATABASE IF EXISTS test_i42gmshr ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:53.848139 [ 31690 ] {c45d9071-aa1d-4774-97e0-5c567bfbc49c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:54.079645 [ 31231 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:54.147753 [ 2731 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:54.247304 [ 3019 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Part -7_63_63_0 is lost forever. 2025.06.12 19:08:54.289197 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:54.386195 [ 31690 ] {e4f303bf-cd68-4f18-b76f-6d97edbfbd51} 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.10057.altinitytest (altinity build)) (from [::1]:46550) (comment: 00082_quantiles.sql) (in query: SELECT CounterID AS k, quantilesExact(0.1, 0.5, 0.9, 0.99, 0.999)(ResolutionWidth) FROM remote('127.0.0.{1,2}', test.hits) GROUP BY k ORDER BY count() DESC, CounterID LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:54.387704 [ 31690 ] {e4f303bf-cd68-4f18-b76f-6d97edbfbd51} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:54.394524 [ 3019 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering -2_58_58_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:54.542699 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:54.808771 [ 23792 ] {365f443f-c68a-44b0-b045-10e84d4d010d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46554) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:54.810129 [ 23792 ] {365f443f-c68a-44b0-b045-10e84d4d010d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:54.963086 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:55.129437 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:55.148801 [ 3002 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:55.397042 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_1_134_52}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:55.495204 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part 0_34_34_0 is lost forever. 2025.06.12 19:08:55.518573 [ 3109 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Part -5_42_42_0 is lost forever. 2025.06.12 19:08:55.543471 [ 3039 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:55.592455 [ 2912 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): Cannot commit empty part 0_34_34_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:08:55.592542 [ 2912 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 0_34_34_0 instead of lost. Will retry later 2025.06.12 19:08:55.698238 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 6_32_32_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:55.716389 [ 2912 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 6_32_32_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:55.788292 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:55.889899 [ 3017 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering 4_67_67_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:55.999887 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:56.149583 [ 2726 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:56.337923 [ 30981 ] {846ef717-6e63-43b9-ac65-97007a9ea834} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46616) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:56.340129 [ 30981 ] {846ef717-6e63-43b9-ac65-97007a9ea834} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:56.544538 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:56.617984 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:56.858835 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:57.150447 [ 2750 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:57.538149 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:57.545756 [ 2727 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:57.802498 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:57.850404 [ 31268 ] {d148d32a-2545-450b-a523-15f663baea94} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46692) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:57.851545 [ 31268 ] {d148d32a-2545-450b-a523-15f663baea94} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:58.151485 [ 2798 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:58.373962 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:58.554298 [ 2912 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Part 6_32_32_0 is lost forever. 2025.06.12 19:08:58.568105 [ 2917 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Part -9_47_47_0 is lost forever. 2025.06.12 19:08:58.569118 [ 3097 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 6_32_32_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:08:58.569261 [ 3097 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 6_32_32_0 instead of lost. Will retry later 2025.06.12 19:08:58.605427 [ 3163 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Cannot commit empty part 6_32_32_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:08:58.606337 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 6_32_32_0 instead of lost. Will retry later 2025.06.12 19:08:58.612838 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): We have part -1_0_49_1_124 covering part -1_0_0_0_83, will not check 2025.06.12 19:08:58.614498 [ 2872 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:58.639614 [ 2912 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 1_77_77_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:58.734558 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:58.791647 [ 3017 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Part 4_67_67_0 is lost forever. 2025.06.12 19:08:58.821473 [ 3019 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Part -2_58_58_0 is lost forever. 2025.06.12 19:08:58.869628 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_74_74_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:59.005469 [ 3018 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_45_45_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:59.006291 [ 2917 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering -2_58_58_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:59.029133 [ 2773 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Cannot commit empty part -2_58_58_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:08:59.029770 [ 2773 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -2_58_58_0 instead of lost. Will retry later 2025.06.12 19:08:59.077050 [ 2952 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_74_74_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:59.155463 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:59.263315 [ 2917 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): Cannot commit empty part -2_58_58_0 with error DB::Exception: Part -2_58_58_0 already exists on replica r_8 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/parts/-2_58_58_0 2025.06.12 19:08:59.263650 [ 2917 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -2_58_58_0 instead of lost. Will retry later 2025.06.12 19:08:59.298792 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:59.322400 [ 2997 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -3_41_41_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:59.391359 [ 2917 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering 9_72_72_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:59.457118 [ 31268 ] {45e3022c-cba4-40ea-abb1-692395ebfbc2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46730) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:59.458588 [ 31268 ] {45e3022c-cba4-40ea-abb1-692395ebfbc2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:59.476311 [ 3069 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering 9_72_72_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:08:59.578943 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:08:59.615611 [ 2886 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:08:59.661748 [ 2997 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Part -3_41_41_0 is lost forever. 2025.06.12 19:08:59.864307 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part 8_74_74_0 is lost forever. 2025.06.12 19:08:59.964378 [ 3018 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Part 8_45_45_0 is lost forever. 2025.06.12 19:08:59.965389 [ 2952 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part 8_74_74_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:08:59.965503 [ 2952 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 8_74_74_0 instead of lost. Will retry later 2025.06.12 19:09:00.068658 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_45_45_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:00.068866 [ 3193 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -7_73_73_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:00.089440 [ 3018 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 9_49_49_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:00.157251 [ 2775 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:00.216969 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:00.227768 [ 2934 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering -4_46_46_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:00.283582 [ 3163 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Cannot commit empty part 8_45_45_0 with error DB::Exception: Part 8_45_45_0 already exists on replica r_4 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/parts/8_45_45_0 2025.06.12 19:09:00.283682 [ 3163 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 8_45_45_0 instead of lost. Will retry later 2025.06.12 19:09:00.469367 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:00.500716 [ 30981 ] {97ea5335-5af6-4d74-a6ae-163bd0d412ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=777). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46760) (comment: 00156_max_execution_speed_sample_merge.sql) (in query: INSERT INTO times SELECT now();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2dfc33 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1d90cc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:00.502830 [ 30981 ] {97ea5335-5af6-4d74-a6ae-163bd0d412ad} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=777). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2dfc33 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1d90cc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:00.586812 [ 2827 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 9_49_49_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:00.617327 [ 3122 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:01.043902 [ 23952 ] {f52aca94-faae-40da-852c-e94036f70018} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46784) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:01.045033 [ 23952 ] {f52aca94-faae-40da-852c-e94036f70018} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:01.081378 [ 31268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:01.179839 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:01.343796 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:01.619380 [ 3024 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:01.877803 [ 30981 ] {173c0ba8-0cc7-444f-abd8-7271c387e8fe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46778) (comment: 00072_compare_date_and_string_index.sql) (in query: SELECT count() FROM test.hits_indexed_by_time WHERE EventTime < '2014-03-18 01:02:03';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:01.879689 [ 30981 ] {173c0ba8-0cc7-444f-abd8-7271c387e8fe} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:01.946041 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:02.180850 [ 3098 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:02.209661 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:02.431327 [ 2912 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Part 1_77_77_0 is lost forever. 2025.06.12 19:09:02.591620 [ 23952 ] {3bf6e803-e1dc-4f24-ac80-afc403f732f2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51098) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:02.592561 [ 23952 ] {3bf6e803-e1dc-4f24-ac80-afc403f732f2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:02.620329 [ 3118 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:02.722008 [ 3152 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 9_49_49_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:02.786688 [ 23952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:02.789071 [ 30981 ] {bc9cb7ef-fff4-451f-9cf8-cd74808b3771} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51090) (comment: 00147_global_in_aggregate_function.sql) (in query: SELECT sum(UserID GLOBAL IN (SELECT UserID FROM test.hits)) FROM remote('127.0.0.{1,2}', test.hits);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:02.790056 [ 30981 ] {bc9cb7ef-fff4-451f-9cf8-cd74808b3771} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.041509 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.110658 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a7456aa7-856d-4768-8b2f-dc442b5d1136::202506_1_262_20}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.182719 [ 2936 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.312101 [ 25390 ] {a4dc2b1d-0f6b-4c7c-9093-e213e03ba5ef} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:50206) (comment: 02790_optimize_skip_unused_shards_join.sql) (in query: DROP DATABASE IF EXISTS test_6hfbiz6d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.313882 [ 25390 ] {a4dc2b1d-0f6b-4c7c-9093-e213e03ba5ef} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.349228 [ 23952 ] {8d8c4ea4-a77c-4108-bd4b-9937291d4e8c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33106) (comment: 02790_optimize_skip_unused_shards_join.sql) (in query: DROP DATABASE IF EXISTS test_6hfbiz6d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.350094 [ 23952 ] {8d8c4ea4-a77c-4108-bd4b-9937291d4e8c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.372628 [ 31268 ] {a5e63dfd-1995-4606-a174-270f6cc07687} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33120) (comment: 02790_optimize_skip_unused_shards_join.sql) (in query: DROP DATABASE IF EXISTS test_6hfbiz6d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.373736 [ 31268 ] {a5e63dfd-1995-4606-a174-270f6cc07687} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.385010 [ 23952 ] {59326123-636e-4c32-9e20-330acc3f02f2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33136) (comment: 02790_optimize_skip_unused_shards_join.sql) (in query: DROP DATABASE IF EXISTS test_6hfbiz6d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.386096 [ 23952 ] {59326123-636e-4c32-9e20-330acc3f02f2} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.394183 [ 31268 ] {79a9df07-b1d8-4427-b940-114811ead14a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33146) (comment: 02790_optimize_skip_unused_shards_join.sql) (in query: DROP DATABASE IF EXISTS test_6hfbiz6d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.495050 [ 31268 ] {79a9df07-b1d8-4427-b940-114811ead14a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.508923 [ 23952 ] {152dc04f-b459-4b65-8e82-7d4dcc0e691f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33162) (comment: 02790_optimize_skip_unused_shards_join.sql) (in query: DROP DATABASE IF EXISTS test_6hfbiz6d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.509833 [ 23952 ] {152dc04f-b459-4b65-8e82-7d4dcc0e691f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.563346 [ 30752 ] {185e9752-21d2-442b-a616-875a29f48aac} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33170) (comment: 02790_optimize_skip_unused_shards_join.sql) (in query: DROP DATABASE IF EXISTS test_6hfbiz6d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.565683 [ 30752 ] {185e9752-21d2-442b-a616-875a29f48aac} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.621129 [ 2927 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.625374 [ 30752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.876225 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.904163 [ 3274 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-6_70_121_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.905980 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-6_70_121_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:03.981898 [ 30981 ] {0b702bef-d0b0-4894-9580-c50b7be6e644} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51134) (comment: 00077_log_tinylog_stripelog.sql) (in query: CHECK TABLE test.hits_tinylog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:03.983055 [ 30981 ] {0b702bef-d0b0-4894-9580-c50b7be6e644} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:04.183467 [ 3129 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:04.568097 [ 31241 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:04.624158 [ 2912 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:04.649628 [ 3018 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Part 9_49_49_0 is lost forever. 2025.06.12 19:09:04.674981 [ 2917 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Part 9_72_72_0 is lost forever. 2025.06.12 19:09:04.679287 [ 3069 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): Cannot commit empty part 9_72_72_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:04.679740 [ 3069 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 9_72_72_0 instead of lost. Will retry later 2025.06.12 19:09:04.702803 [ 2827 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Cannot commit empty part 9_49_49_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:04.703796 [ 2827 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 9_49_49_0 instead of lost. Will retry later 2025.06.12 19:09:04.712040 [ 31241 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:04.743277 [ 3069 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering -4_46_46_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:04.762966 [ 3018 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering -1_52_52_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:04.789011 [ 2827 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering -1_52_52_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:04.805623 [ 2778 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering -4_69_69_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:04.806615 [ 3152 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): Cannot commit empty part 9_49_49_0 with error DB::Exception: Part 9_49_49_0 already exists on replica r_4 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/parts/9_49_49_0 2025.06.12 19:09:04.827489 [ 3152 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 9_49_49_0 instead of lost. Will retry later 2025.06.12 19:09:04.834349 [ 30753 ] {764651f2-52e6-4445-af4b-b68c958e0316} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51156) (comment: 00509_extended_storage_definition_syntax_zookeeper.sql) (in query: INSERT INTO replicated_with_sampling 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d92d 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447e8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:04.883314 [ 3193 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Part -7_73_73_0 is lost forever. 2025.06.12 19:09:04.946940 [ 30753 ] {764651f2-52e6-4445-af4b-b68c958e0316} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02)) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d92d 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x0000000017d447e8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:05.067820 [ 31263 ] {fc2b1208-ed63-4292-8bb4-d39e9a0000b1} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33226) (comment: 00509_extended_storage_definition_syntax_zookeeper.sql) (in query: DROP DATABASE IF EXISTS test_slupgmk5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d92d 5. ./src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a967 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>>>&) @ 0x0000000017c6e9aa 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:05.069347 [ 31263 ] {fc2b1208-ed63-4292-8bb4-d39e9a0000b1} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02)) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000017c2d92d 5. ./src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a967 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>>>&) @ 0x0000000017c6e9aa 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:05.147549 [ 31266 ] {2932eee2-5da4-4b44-905d-201f5e5e47b1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51170) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:05.149598 [ 31266 ] {2932eee2-5da4-4b44-905d-201f5e5e47b1} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:05.224558 [ 3181 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:05.408428 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:05.553431 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:05.625040 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:05.779946 [ 2827 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Will not create empty part instead of lost -1_52_52_0, because it's going to be removed (by range -1_52_52_0) 2025.06.12 19:09:05.780950 [ 2827 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -1_52_52_0 instead of lost. Will retry later 2025.06.12 19:09:05.817168 [ 3018 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Will not create empty part instead of lost -1_52_52_0, because it's going to be removed (by range -1_52_52_0) 2025.06.12 19:09:05.817602 [ 3018 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -1_52_52_0 instead of lost. Will retry later 2025.06.12 19:09:05.875962 [ 3152 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering -1_52_52_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:05.920418 [ 2760 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -4_46_46_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:06.094736 [ 17179 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.095828 [ 3094 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.096356 [ 3128 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.097071 [ 2759 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.097403 [ 2690 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.097818 [ 2796 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.098274 [ 2723 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.098436 [ 2728 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.098756 [ 2731 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.098968 [ 3195 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.099482 [ 2802 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.099951 [ 3142 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.100251 [ 3149 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.100569 [ 3111 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.101338 [ 3090 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.101806 [ 2736 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.101810 [ 2773 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.102399 [ 3082 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.102646 [ 3146 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.102929 [ 2717 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.103588 [ 3156 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.104074 [ 2825 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.105141 [ 2850 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:06.106933 [ 3296 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4522: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b0031 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.107116 [ 2934 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part -4_46_46_0 with error Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/log_pointer 2025.06.12 19:09:06.107485 [ 2778 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): Cannot commit empty part -4_69_69_0 with error Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/-4_69_69_0 2025.06.12 19:09:06.107533 [ 3130 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.107593 [ 2934 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -4_46_46_0 instead of lost. Will retry later 2025.06.12 19:09:06.107707 [ 2778 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -4_69_69_0 instead of lost. Will retry later 2025.06.12 19:09:06.107828 [ 3197 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.107959 [ 3069 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): Cannot commit empty part -4_46_46_0 with error Coordination::Exception: Session expired 2025.06.12 19:09:06.108050 [ 3307 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001ae6f388 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193779b0 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.108082 [ 3069 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -4_46_46_0 instead of lost. Will retry later 2025.06.12 19:09:06.108061 [ 2765 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.108407 [ 3300 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001ae6f388 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193779b0 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.108646 [ 3303 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001ae6f388 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193779b0 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.108890 [ 3292 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/parts/9_124_124_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001ae6d9dc 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1818: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937082c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 18. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.109869 [ 2778 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.109903 [ 3069 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.109998 [ 2934 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.110387 [ 3130 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.112743 [ 3130 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.116628 [ 3152 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): Cannot commit empty part -1_52_52_0 with error Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/pinned_part_uuids 2025.06.12 19:09:06.116731 [ 3152 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -1_52_52_0 instead of lost. Will retry later 2025.06.12 19:09:06.117542 [ 3152 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.119712 [ 3293 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b04ab 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.120161 [ 3158 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.121328 [ 2789 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.123017 [ 2760 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Cannot commit empty part -4_46_46_0 with error Coordination::Exception: Session expired 2025.06.12 19:09:06.123074 [ 2760 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -4_46_46_0 instead of lost. Will retry later 2025.06.12 19:09:06.123523 [ 3305 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b04ab 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.124379 [ 2846 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.124719 [ 2976 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.124399 [ 2770 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.125657 [ 3151 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.125810 [ 2976 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.127030 [ 3054 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.127547 [ 2976 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.129271 [ 2996 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.129887 [ 2722 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.129951 [ 2996 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.182399 [ 3306 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001ae6f388 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000193779b0 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.231318 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.275784 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:06.285861 [ 3014 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.401100 [ 3018 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/parts/-9_47_47_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::findLocalPart(String const&) @ 0x0000000019d6576a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d65ae2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.402678 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:06.426164 [ 3064 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.427623 [ 3064 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.429122 [ 3064 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.454745 [ 2827 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreePartCheckThread::searchForMissingPartOnOtherReplicas(String const&) const @ 0x0000000019d625d2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:492: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c7d8 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.461610 [ 3192 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d824d7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.461714 [ 2694 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d824d7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.461752 [ 2713 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d824d7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.462441 [ 2694 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.462967 [ 2713 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.491402 [ 2889 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 11. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::dropPartImpl(std::shared_ptr&, String, DB::ReplicatedMergeTreeLogEntry&, bool, bool) @ 0x000000001940f32f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::dropPartNoWaitNoThrow(String const&) @ 0x000000001940e954 13. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::MergeTreeData::clearEmptyParts() @ 0x00000000199d1616 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d410c0 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 17. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.492113 [ 2742 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.504644 [ 3083 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 13. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::dropPartImpl(std::shared_ptr&, String, DB::ReplicatedMergeTreeLogEntry&, bool, bool) @ 0x000000001940f32f 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::dropPartNoWaitNoThrow(String const&) @ 0x000000001940e954 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::MergeTreeData::clearEmptyParts() @ 0x00000000199d1616 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d410c0 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 19. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 21. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.504675 [ 3166 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 13. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::dropPartImpl(std::shared_ptr&, String, DB::ReplicatedMergeTreeLogEntry&, bool, bool) @ 0x000000001940f32f 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::dropPartNoWaitNoThrow(String const&) @ 0x000000001940e954 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::MergeTreeData::clearEmptyParts() @ 0x00000000199d1616 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d410c0 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 19. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 21. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.524949 [ 2988 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 11. ./contrib/llvm-project/libcxx/include/optional:285: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193ced7b 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.525888 [ 2988 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cd4d1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.545470 [ 3283 ] {} d5c3c149-fa7e-4536-98d4-499e10c276c8::-6_0_54_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 14. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.545589 [ 3274 ] {} ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::4_0_56_3_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 14. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.546021 [ 3283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d5c3c149-fa7e-4536-98d4-499e10c276c8::-6_0_54_1}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 14. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.546204 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e::4_0_56_3_1}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 14. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:0: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x00000000199560d4 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d359da 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.552608 [ 2994 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering -3_70_70_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:06.586142 [ 2994 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part -3_70_70_0 is lost forever. 2025.06.12 19:09:06.593779 [ 2994 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering -4_46_46_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:06.620271 [ 3308 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1347: Coordination::ZooKeeper::remove(String const&, int, std::function) @ 0x000000001ae5545a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add21c3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:532: zkutil::ZooKeeper::removeImpl(String const&, int) @ 0x000000001add1d73 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add248a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1201: DB::ReplicatedMergeTreeQueue::removePartProducingOpsInRange(std::shared_ptr, DB::MergeTreePartInfo const&, std::optional const&) @ 0x0000000019d931bd 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::executeDropRange(DB::ReplicatedMergeTreeLogEntry const&) @ 0x000000001937e0fc 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2061: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a325 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.620337 [ 3312 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1347: Coordination::ZooKeeper::remove(String const&, int, std::function) @ 0x000000001ae5545a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add21c3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:532: zkutil::ZooKeeper::removeImpl(String const&, int) @ 0x000000001add1d73 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add248a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1201: DB::ReplicatedMergeTreeQueue::removePartProducingOpsInRange(std::shared_ptr, DB::MergeTreePartInfo const&, std::optional const&) @ 0x0000000019d931bd 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::executeDropRange(DB::ReplicatedMergeTreeLogEntry const&) @ 0x000000001937e0fc 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2061: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a325 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.620270 [ 3311 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1347: Coordination::ZooKeeper::remove(String const&, int, std::function) @ 0x000000001ae5545a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add21c3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:532: zkutil::ZooKeeper::removeImpl(String const&, int) @ 0x000000001add1d73 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add248a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1201: DB::ReplicatedMergeTreeQueue::removePartProducingOpsInRange(std::shared_ptr, DB::MergeTreePartInfo const&, std::optional const&) @ 0x0000000019d931bd 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::executeDropRange(DB::ReplicatedMergeTreeLogEntry const&) @ 0x000000001937e0fc 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2061: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a325 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.620678 [ 3314 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1347: Coordination::ZooKeeper::remove(String const&, int, std::function) @ 0x000000001ae5545a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add21c3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:532: zkutil::ZooKeeper::removeImpl(String const&, int) @ 0x000000001add1d73 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add248a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1201: DB::ReplicatedMergeTreeQueue::removePartProducingOpsInRange(std::shared_ptr, DB::MergeTreePartInfo const&, std::optional const&) @ 0x0000000019d931bd 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::executeDropRange(DB::ReplicatedMergeTreeLogEntry const&) @ 0x000000001937e0fc 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2061: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a325 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.620727 [ 3310 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1347: Coordination::ZooKeeper::remove(String const&, int, std::function) @ 0x000000001ae5545a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add21c3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:532: zkutil::ZooKeeper::removeImpl(String const&, int) @ 0x000000001add1d73 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add248a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1201: DB::ReplicatedMergeTreeQueue::removePartProducingOpsInRange(std::shared_ptr, DB::MergeTreePartInfo const&, std::optional const&) @ 0x0000000019d931bd 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::executeDropRange(DB::ReplicatedMergeTreeLogEntry const&) @ 0x000000001937e0fc 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2061: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a325 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.620353 [ 3309 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1347: Coordination::ZooKeeper::remove(String const&, int, std::function) @ 0x000000001ae5545a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add21c3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:532: zkutil::ZooKeeper::removeImpl(String const&, int) @ 0x000000001add1d73 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add248a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1201: DB::ReplicatedMergeTreeQueue::removePartProducingOpsInRange(std::shared_ptr, DB::MergeTreePartInfo const&, std::optional const&) @ 0x0000000019d931bd 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::executeDropRange(DB::ReplicatedMergeTreeLogEntry const&) @ 0x000000001937e0fc 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2061: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a325 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.620863 [ 3315 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1347: Coordination::ZooKeeper::remove(String const&, int, std::function) @ 0x000000001ae5545a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add21c3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:532: zkutil::ZooKeeper::removeImpl(String const&, int) @ 0x000000001add1d73 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add248a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1201: DB::ReplicatedMergeTreeQueue::removePartProducingOpsInRange(std::shared_ptr, DB::MergeTreePartInfo const&, std::optional const&) @ 0x0000000019d931bd 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::executeDropRange(DB::ReplicatedMergeTreeLogEntry const&) @ 0x000000001937e0fc 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2061: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a325 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.620967 [ 3313 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1347: Coordination::ZooKeeper::remove(String const&, int, std::function) @ 0x000000001ae5545a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add21c3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:532: zkutil::ZooKeeper::removeImpl(String const&, int) @ 0x000000001add1d73 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x000000001add248a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1201: DB::ReplicatedMergeTreeQueue::removePartProducingOpsInRange(std::shared_ptr, DB::MergeTreePartInfo const&, std::optional const&) @ 0x0000000019d931bd 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::executeDropRange(DB::ReplicatedMergeTreeLogEntry const&) @ 0x000000001937e0fc 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2061: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a325 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dec9 15. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.626024 [ 2952 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.640153 [ 2797 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x0000000018209f6e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000018209c2c 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::BaseMergePredicate::getCommittingBlocks(std::shared_ptr&, String const&, std::shared_ptr) @ 0x0000000019db4e23 9. ./contrib/llvm-project/libcxx/include/new:246: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac3b3 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 11. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::dropPartImpl(std::shared_ptr&, String, DB::ReplicatedMergeTreeLogEntry&, bool, bool) @ 0x000000001940f32f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::dropPartNoWaitNoThrow(String const&) @ 0x000000001940e954 13. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::MergeTreeData::clearEmptyParts() @ 0x00000000199d1616 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d410c0 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 17. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.641517 [ 2797 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.643003 [ 2797 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.735724 [ 3299 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 19. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.735856 [ 3297 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 19. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.735962 [ 3294 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 19. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.736779 [ 3301 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001ae6d01d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001937019d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x000000001937544f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1964: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x0000000019377720 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x00000000193a339f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193940d2 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 19. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.746873 [ 3281 ] {} 764b68fe-a6f6-4b5d-ae50-c17628a53bc9::1_0_124_2 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4522: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b0031 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000019d36e32 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d35b5c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.747272 [ 3281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {764b68fe-a6f6-4b5d-ae50-c17628a53bc9::1_0_124_2}: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4522: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193b0031 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000019d36e32 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d35b5c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.766661 [ 2994 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part -4_46_46_0 is lost forever. 2025.06.12 19:09:06.781491 [ 2994 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 5_47_47_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:06.802765 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -5_52_52_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:06.809981 [ 3303 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193af85f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 17. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.810016 [ 3296 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193af85f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 17. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.810039 [ 3307 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193af85f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 17. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.810124 [ 3292 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193af85f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 17. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.810124 [ 3293 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193af85f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 17. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.810169 [ 3302 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193af85f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 17. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.810170 [ 3304 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::findReplicaHavingCoveringPartImplLowLevel(DB::ReplicatedMergeTreeLogEntry*, String const&, String&, bool) @ 0x00000000193af85f 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000193901f0 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937c676 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 17. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.823251 [ 31241 ] {08a31c4e-5f15-4842-a605-73e63b0516b4} 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.10057.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51746) (comment: 00159_parallel_formatting_http.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a,MobilePhoneModel as b,ClientIP6 as c FROM test.hits ORDER BY a,b,c LIMIT 1000000 Format CSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a5056b1 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a503fc5 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000001a506a03 10. ./src/Processors/Formats/IOutputFormat.h:123: DB::IOutputFormat::work() @ 0x000000001a3019c5 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:06.824778 [ 31241 ] {08a31c4e-5f15-4842-a605-73e63b0516b4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a5056b1 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a503fc5 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000001a506a03 10. ./src/Processors/Formats/IOutputFormat.h:123: DB::IOutputFormat::work() @ 0x000000001a3019c5 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2dff1a 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&)>) @ 0x000000001821b8bc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.853172 [ 31263 ] {65459989-9a27-4587-8b7f-24812e995332} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51242) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:06.854934 [ 31263 ] {65459989-9a27-4587-8b7f-24812e995332} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:06.931080 [ 2994 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part 5_47_47_0 is lost forever. 2025.06.12 19:09:06.987792 [ 3300 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2084: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a489 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.987857 [ 3295 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2084: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a489 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.987957 [ 3305 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2084: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a489 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.988011 [ 3298 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2084: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a489 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:06.988067 [ 3306 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2084: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001937a489 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948cea1 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x0000000019da11ca 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3645: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x00000000193cc05b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001948dd09 14. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x00000000194be98e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001999154c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019992042 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997742 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:07.021370 [ 2909 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering -5_52_52_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.119330 [ 2994 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_58_58_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.128819 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering -6_69_69_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.131127 [ 2933 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:07.152529 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering -6_69_69_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.168540 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:07.233922 [ 3016 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:07.244545 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Part -6_69_69_0 is lost forever. 2025.06.12 19:09:07.247343 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_58_58_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.249632 [ 3066 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): Cannot commit empty part -6_69_69_0 with error DB::Exception: Part -6_69_69_0 already exists on replica r_8 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/parts/-6_69_69_0 2025.06.12 19:09:07.249726 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -6_69_69_0 instead of lost. Will retry later 2025.06.12 19:09:07.260289 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:07.262081 [ 2909 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Part -5_52_52_0 is lost forever. 2025.06.12 19:09:07.263110 [ 2716 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Cannot commit empty part -5_52_52_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:07.263232 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -5_52_52_0 instead of lost. Will retry later 2025.06.12 19:09:07.435201 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering -8_54_54_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.436527 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering -8_54_54_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.448937 [ 3108 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_58_58_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.475072 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -8_67_67_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.493637 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering -8_54_54_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:07.626797 [ 3165 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:07.629954 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Part -8_67_67_0 is lost forever. 2025.06.12 19:09:07.821576 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Part -8_54_54_0 is lost forever. 2025.06.12 19:09:07.827480 [ 3096 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): Cannot commit empty part -8_54_54_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:07.827561 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -8_54_54_0 instead of lost. Will retry later 2025.06.12 19:09:07.855057 [ 3066 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): Cannot commit empty part -8_54_54_0 with error Coordination::Exception: Transaction failed (Node exists): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/parts/-8_54_54_0 2025.06.12 19:09:07.855199 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -8_54_54_0 instead of lost. Will retry later 2025.06.12 19:09:07.857433 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Part 0_58_58_0 is lost forever. 2025.06.12 19:09:07.906849 [ 2994 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Cannot commit empty part 0_58_58_0 with error DB::Exception: Part 0_58_58_0 already exists on replica r_0 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/parts/0_58_58_0 2025.06.12 19:09:07.906981 [ 2994 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 0_58_58_0 instead of lost. Will retry later 2025.06.12 19:09:07.992748 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:07.995419 [ 3108 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 0_58_58_0 with error DB::Exception: Part 0_58_58_0 already exists on replica r_0 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/parts/0_58_58_0 2025.06.12 19:09:07.995536 [ 3108 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 0_58_58_0 instead of lost. Will retry later 2025.06.12 19:09:08.003988 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering 3_59_59_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.013685 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 4_59_59_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.030874 [ 3108 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 4_59_59_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.031711 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_77_77_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.032335 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_61_61_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.042354 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_61_61_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.047834 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 3_59_59_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.090442 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:08.131900 [ 3152 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:08.234801 [ 2846 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:08.394344 [ 31266 ] {5330f548-9b01-4fa4-92be-1e0ebec4e4da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51296) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:08.395514 [ 31266 ] {5330f548-9b01-4fa4-92be-1e0ebec4e4da} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:08.432093 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Part 4_59_59_0 is lost forever. 2025.06.12 19:09:08.434191 [ 3108 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 4_59_59_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:08.434276 [ 3108 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 4_59_59_0 instead of lost. Will retry later 2025.06.12 19:09:08.446314 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Part 0_77_77_0 is lost forever. 2025.06.12 19:09:08.455178 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part 3_59_59_0 is lost forever. 2025.06.12 19:09:08.456203 [ 2716 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Cannot commit empty part 3_59_59_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:08.456375 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 3_59_59_0 instead of lost. Will retry later 2025.06.12 19:09:08.463723 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Part 0_61_61_0 is lost forever. 2025.06.12 19:09:08.467660 [ 2900 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part 0_61_61_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:08.467763 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 0_61_61_0 instead of lost. Will retry later 2025.06.12 19:09:08.472078 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part 2_0_54_1 covering part 2_28_28_0, will not check 2025.06.12 19:09:08.478933 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_56_56_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.482330 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_56_56_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.487553 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_56_56_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.497257 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_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.06.12 19:09:08.503489 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_56_56_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.503649 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_56_56_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.507666 [ 3105 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 2_56_56_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.533798 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Part 2_56_56_0 is lost forever. 2025.06.12 19:09:08.535559 [ 2716 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Cannot commit empty part 2_56_56_0 with error Coordination::Exception: Transaction failed (Node exists): Op #4, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/parts/2_56_56_0 2025.06.12 19:09:08.535698 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 2_56_56_0 instead of lost. Will retry later 2025.06.12 19:09:08.536561 [ 2813 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): Cannot commit empty part 2_56_56_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:08.536663 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 2_56_56_0 instead of lost. Will retry later 2025.06.12 19:09:08.541538 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Part 2_71_71_0 is lost forever. 2025.06.12 19:09:08.546401 [ 2911 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): Cannot commit empty part 2_56_56_0 with error Coordination::Exception: Transaction failed (Node exists): Op #6, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/parts/2_56_56_0 2025.06.12 19:09:08.546640 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 2_56_56_0 instead of lost. Will retry later 2025.06.12 19:09:08.547126 [ 3105 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 2_56_56_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:08.547248 [ 3105 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 2_56_56_0 instead of lost. Will retry later 2025.06.12 19:09:08.549666 [ 2900 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part 2_56_56_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:08.549932 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 2_56_56_0 instead of lost. Will retry later 2025.06.12 19:09:08.627575 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:08.825133 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:08.841895 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -4_69_69_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.848077 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 6_60_60_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.850908 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering 4_74_74_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.853548 [ 3105 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 6_60_60_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:08.891418 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a7456aa7-856d-4768-8b2f-dc442b5d1136::202506_135_263_17}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:08.917341 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:09.132693 [ 3019 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:09.235795 [ 3187 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:09.397891 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 6_60_60_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:09.479789 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering 4_74_74_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:09.598135 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering 4_74_74_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:09.628454 [ 3012 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:09.651031 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:09.741848 [ 2932 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:09.757730 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:09.840967 [ 31263 ] {e942a9e7-aac1-42f1-91cb-a9a5f429dae8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51356) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:09.842612 [ 31263 ] {e942a9e7-aac1-42f1-91cb-a9a5f429dae8} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:10.133665 [ 2868 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:10.181652 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part 6_60_60_0 is lost forever. 2025.06.12 19:09:10.236978 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:10.262915 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Part -4_69_69_0 is lost forever. 2025.06.12 19:09:10.265973 [ 3105 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 6_60_60_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:10.266122 [ 3105 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 6_60_60_0 instead of lost. Will retry later 2025.06.12 19:09:10.277509 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering 4_74_74_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.279880 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 5_57_57_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.289856 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Part 4_74_74_0 is lost forever. 2025.06.12 19:09:10.386145 [ 2900 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part 4_74_74_0 with error Coordination::Exception: Transaction failed (Node exists): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/parts/4_74_74_0 2025.06.12 19:09:10.386506 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 4_74_74_0 instead of lost. Will retry later 2025.06.12 19:09:10.389410 [ 2813 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): Cannot commit empty part 6_60_60_0 with error Coordination::Exception: Transaction failed (Node exists): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/6_60_60_0 2025.06.12 19:09:10.389697 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 6_60_60_0 instead of lost. Will retry later 2025.06.12 19:09:10.396622 [ 3105 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 5_57_57_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.401874 [ 3066 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): Cannot commit empty part 4_74_74_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:10.402013 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 4_74_74_0 instead of lost. Will retry later 2025.06.12 19:09:10.411194 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering 5_57_57_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.422767 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 5_57_57_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.448945 [ 2716 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Cannot commit empty part 4_74_74_0 with error DB::Exception: Part 4_74_74_0 already exists on replica r_8 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/parts/4_74_74_0 2025.06.12 19:09:10.449294 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 4_74_74_0 instead of lost. Will retry later 2025.06.12 19:09:10.454990 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering 5_57_57_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.485496 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:10.505304 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part 5_57_57_0 is lost forever. 2025.06.12 19:09:10.590881 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:10.606259 [ 2813 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): Cannot commit empty part 5_57_57_0 with error DB::Exception: Part 5_57_57_0 already exists on replica r_5 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/5_57_57_0 2025.06.12 19:09:10.606358 [ 2813 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 5_57_57_0 instead of lost. Will retry later 2025.06.12 19:09:10.629353 [ 2861 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:10.649210 [ 3105 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 5_57_57_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:10.649344 [ 3105 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 5_57_57_0 instead of lost. Will retry later 2025.06.12 19:09:10.650931 [ 2900 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part 5_57_57_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:10.651014 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 5_57_57_0 instead of lost. Will retry later 2025.06.12 19:09:10.663034 [ 3066 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): Cannot commit empty part 5_57_57_0 with error DB::Exception: Part 5_57_57_0 already exists on replica r_5 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/5_57_57_0 2025.06.12 19:09:10.663162 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 5_57_57_0 instead of lost. Will retry later 2025.06.12 19:09:10.664453 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_76_76_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.692403 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_76_76_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.702005 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_76_76_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.713946 [ 3162 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_76_76_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:10.782807 [ 2766 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:11.003069 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_76_76_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:11.017992 [ 2915 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_76_76_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:11.134377 [ 2835 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:11.234390 [ 2925 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): No replica has part covering 8_76_76_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:11.238371 [ 2829 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:11.295117 [ 2911 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): Part 8_76_76_0 is lost forever. 2025.06.12 19:09:11.312322 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:11.362392 [ 2925 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): Cannot commit empty part 8_76_76_0 with error DB::Exception: Part 8_76_76_0 already exists on replica r_5 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/8_76_76_0 2025.06.12 19:09:11.362530 [ 2925 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 8_76_76_0 instead of lost. Will retry later 2025.06.12 19:09:11.363102 [ 2915 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): Cannot commit empty part 8_76_76_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:11.363207 [ 2915 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 8_76_76_0 instead of lost. Will retry later 2025.06.12 19:09:11.378250 [ 3096 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): Cannot commit empty part 8_76_76_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:11.378586 [ 3096 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 8_76_76_0 instead of lost. Will retry later 2025.06.12 19:09:11.380214 [ 2716 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Cannot commit empty part 8_76_76_0 with error DB::Exception: Part 8_76_76_0 already exists on replica r_5 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/8_76_76_0 2025.06.12 19:09:11.380531 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 8_76_76_0 instead of lost. Will retry later 2025.06.12 19:09:11.383039 [ 3162 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): Cannot commit empty part 8_76_76_0 with error DB::Exception: Found part on another replica, probably it was already replaced 2025.06.12 19:09:11.383190 [ 3162 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 8_76_76_0 instead of lost. Will retry later 2025.06.12 19:09:11.428384 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:11.442318 [ 3066 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): Cannot commit empty part 8_76_76_0 with error DB::Exception: Part 8_76_76_0 already exists on replica r_5 on path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/parts/8_76_76_0 2025.06.12 19:09:11.442831 [ 3066 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): Cannot create empty part 8_76_76_0 instead of lost. Will retry later 2025.06.12 19:09:11.630158 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:11.736455 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): No replica has part covering -3_70_70_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.12 19:09:11.766674 [ 2716 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): Will not create empty part instead of lost -3_70_70_0, because there's no covering part in replication queue 2025.06.12 19:09:11.766938 [ 2716 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): Cannot create empty part -3_70_70_0 instead of lost. Will retry later 2025.06.12 19:09:11.783888 [ 2690 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:11.833684 [ 31266 ] {4c7b935d-00f6-43cc-8412-d61e2e2c259f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51408) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:11.835844 [ 31266 ] {4c7b935d-00f6-43cc-8412-d61e2e2c259f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:11.888582 [ 3278 ] {} a991c6ec-26b8-4e79-9287-7cf7432a7148::4_0_56_3_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:11.935643 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a991c6ec-26b8-4e79-9287-7cf7432a7148::4_0_56_3_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:12.052135 [ 3272 ] {} 7779edca-b815-4b88-adca-6384948e7a52::5_0_52_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:12.053212 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::5_0_52_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:12.126676 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_161_32}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:12.137653 [ 2694 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:12.163277 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:12.240067 [ 3128 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:12.302715 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:12.630960 [ 2792 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:12.784909 [ 2686 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:13.004841 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:13.141333 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:13.146776 [ 2803 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:13.304530 [ 3054 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:13.544956 [ 31266 ] {c2d125f8-eb99-4671-9978-68a0da35bda7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48126) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:13.546890 [ 31266 ] {c2d125f8-eb99-4671-9978-68a0da35bda7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:13.636902 [ 2958 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:13.811571 [ 2715 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:13.879720 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:13.998352 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:14.150068 [ 2928 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:14.307253 [ 2912 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:14.637617 [ 3041 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:14.700471 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:14.814983 [ 2756 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:14.899516 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:15.151331 [ 3140 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:15.310054 [ 3141 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:15.368580 [ 31266 ] {40a6e3f8-6f63-4875-acf8-e252f321461f} 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.10057.altinitytest (altinity build)) (from [::1]:48194) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:15.426142 [ 31266 ] {40a6e3f8-6f63-4875-acf8-e252f321461f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:15.525836 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:15.638929 [ 2802 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:15.728728 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:15.858464 [ 2724 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:16.153569 [ 2720 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:16.312336 [ 2715 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:16.359852 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:16.587811 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:16.640556 [ 3109 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:16.860098 [ 3100 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:16.877647 [ 31266 ] {c0c7ae97-6d6b-4763-addd-b8f283adecb9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48252) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:16.880985 [ 31266 ] {c0c7ae97-6d6b-4763-addd-b8f283adecb9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:17.149053 [ 3282 ] {} d5c3c149-fa7e-4536-98d4-499e10c276c8::-5_0_115_2 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:17.150079 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d5c3c149-fa7e-4536-98d4-499e10c276c8::-5_0_115_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:17.158565 [ 2754 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:17.194892 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:17.317542 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:17.443196 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:17.651398 [ 2957 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:17.862119 [ 2888 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.047842 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:18.163448 [ 2939 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.319743 [ 3036 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.329968 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:18.380338 [ 31266 ] {6d73efae-db9a-4b43-8d45-29049f914be3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48312) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:18.385273 [ 31266 ] {6d73efae-db9a-4b43-8d45-29049f914be3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:18.653170 [ 2872 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.808467 [ 3272 ] {} 764b68fe-a6f6-4b5d-ae50-c17628a53bc9::9_0_95_2 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.809901 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {764b68fe-a6f6-4b5d-ae50-c17628a53bc9::9_0_95_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.842648 [ 3270 ] {} ba153c9d-0129-4209-ab37-275e8cf118ba::1_0_124_2 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.843529 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ba153c9d-0129-4209-ab37-275e8cf118ba::1_0_124_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.849166 [ 3278 ] {} ba153c9d-0129-4209-ab37-275e8cf118ba::9_0_95_2 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.849795 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ba153c9d-0129-4209-ab37-275e8cf118ba::9_0_95_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.864928 [ 3058 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:18.875886 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:19.167328 [ 3188 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:19.230563 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:19.320910 [ 3197 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:19.655096 [ 3054 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:19.712356 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:19.866028 [ 2821 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:19.879485 [ 31263 ] {fb0bdf47-d6ce-422b-87a3-d011ae8c4d12} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48358) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:19.881820 [ 31263 ] {fb0bdf47-d6ce-422b-87a3-d011ae8c4d12} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:20.057197 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:20.169102 [ 2927 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:20.313271 [ 3276 ] {} 38b1b594-8cf2-483c-bb28-07c4a85bce95::-5_0_115_2 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:20.313786 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {38b1b594-8cf2-483c-bb28-07c4a85bce95::-5_0_115_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:20.329991 [ 3276 ] {} 38b1b594-8cf2-483c-bb28-07c4a85bce95::-6_0_54_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:20.330587 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {38b1b594-8cf2-483c-bb28-07c4a85bce95::-6_0_54_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:20.375744 [ 2920 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:20.539512 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:20.657519 [ 2699 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:20.867074 [ 2812 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:20.946459 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:21.172859 [ 3157 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:21.368576 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:21.378089 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:21.659885 [ 3099 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:21.828212 [ 31263 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:21.868452 [ 31266 ] {00ead10c-560d-44ff-9628-d59acf02a5e9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48400) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:21.869306 [ 2885 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:21.870262 [ 31266 ] {00ead10c-560d-44ff-9628-d59acf02a5e9} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:22.012082 [ 3282 ] {} 38b1b594-8cf2-483c-bb28-07c4a85bce95::-3_0_49_1_39 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:22.012666 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {38b1b594-8cf2-483c-bb28-07c4a85bce95::-3_0_49_1_39}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:22.154278 [ 2833 ] {} test_9.alter_table_5 (ReplicatedMergeTreePartCheckThread): We have part 2_0_54_1 covering part 2_28_28_0, will not check 2025.06.12 19:09:22.177892 [ 2848 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): We have part 2_0_54_1 covering part 2_28_28_0, will not check 2025.06.12 19:09:22.177914 [ 3118 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:22.214680 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:22.326820 [ 3271 ] {} 7779edca-b815-4b88-adca-6384948e7a52::-7_73_126_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:22.327489 [ 3271 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::-7_73_126_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:22.384040 [ 2967 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:22.662314 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:22.681743 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:22.867384 [ 2858 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): We have part -6_0_54_1 covering part -6_31_31_0, will not check 2025.06.12 19:09:22.870974 [ 2940 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:23.081291 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:23.179412 [ 2721 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:23.469973 [ 3110 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:23.625305 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:23.663649 [ 3164 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:23.872023 [ 2711 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:23.937685 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:24.180488 [ 2814 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:24.461055 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:24.471994 [ 2778 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:24.664830 [ 3087 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:24.762384 [ 30749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:24.873034 [ 3178 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:24.957625 [ 31266 ] {ed1288d3-6370-48c7-a1ef-019850442579} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/-1_0_126_2_124/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 0 with max_rows_to_read = 26820): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34808) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5ae03 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 16. DB::ReadBuffer::next() @ 0x0000000007b3417b 17. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 18. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 21. ./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>>&) @ 0x0000000019be070e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 2025.06.12 19:09:25.106026 [ 31266 ] {ed1288d3-6370-48c7-a1ef-019850442579} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/-1_0_126_2_124/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 0 with max_rows_to_read = 26820): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5ae03 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 16. DB::ReadBuffer::next() @ 0x0000000007b3417b 17. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 18. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 21. ./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>>&) @ 0x0000000019be070e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 2025.06.12 19:09:25.181729 [ 3177 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:25.293812 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:25.473019 [ 2724 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:25.585632 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:25.665709 [ 3124 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:25.873777 [ 3157 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:26.112226 [ 31263 ] {37faa64a-6d7b-40ab-b8d0-52f387d1eb7a} executeQuery: Code: 277. DB::Exception: Primary key (mortonEncode(x, y)) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34778) (comment: 02899_indexing_by_space_filling_curves.sql) (in query: SELECT count() FROM test WHERE x >= 10 AND x <= 20 AND y >= 20 AND y <= 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000019224260 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: 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) @ 0x000000001a933609 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1a787 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.112896 [ 31263 ] {37faa64a-6d7b-40ab-b8d0-52f387d1eb7a} TCPHandler: Code: 277. DB::Exception: Primary key (mortonEncode(x, y)) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000019224260 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: 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) @ 0x000000001a933609 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa1a787 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1bae 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.119716 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.125354 [ 31263 ] {d9f14695-2b86-4a02-89c3-c1fbc96cc504} executeQuery: Code: 57. DB::Exception: Table test_20fnk9xn.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34778) (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 = 1, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 41, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 212783974, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 4388758, merge_max_block_size = 763, old_parts_lifetime = 270., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5902621, concurrent_part_removal_threshold = 8, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 99556, primary_key_compress_block_size = 55542), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.125854 [ 31263 ] {d9f14695-2b86-4a02-89c3-c1fbc96cc504} TCPHandler: Code: 57. DB::Exception: Table test_20fnk9xn.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.173998 [ 31241 ] {8b14b9bb-d81e-4c36-b6b3-8b57d87718d7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48612) (comment: 02899_indexing_by_space_filling_curves.sql) (in query: DROP DATABASE IF EXISTS test_20fnk9xn ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.174824 [ 31241 ] {8b14b9bb-d81e-4c36-b6b3-8b57d87718d7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:26.180659 [ 31266 ] {858b4e46-3a43-4bcb-994b-235a53961fb7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48618) (comment: 02899_indexing_by_space_filling_curves.sql) (in query: DROP DATABASE IF EXISTS test_20fnk9xn ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.181363 [ 31266 ] {858b4e46-3a43-4bcb-994b-235a53961fb7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:26.182868 [ 3103 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:26.421465 [ 31266 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.473805 [ 3012 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:26.666716 [ 2978 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:26.767106 [ 31230 ] {68438ce8-dcdc-4559-a55a-4767fb90ac56} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34874) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.768365 [ 31230 ] {68438ce8-dcdc-4559-a55a-4767fb90ac56} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:26.874887 [ 2905 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:26.979840 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:27.183803 [ 3158 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:27.248944 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:27.474668 [ 2984 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:27.667599 [ 3174 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:27.817525 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:27.863943 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a7456aa7-856d-4768-8b2f-dc442b5d1136::202506_1_267_20}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:27.875798 [ 2806 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:28.089688 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:28.184564 [ 3072 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:28.234286 [ 31230 ] {57d882c7-30db-4d28-9c98-038a2a846ad0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34934) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:28.235580 [ 31230 ] {57d882c7-30db-4d28-9c98-038a2a846ad0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:28.475616 [ 2976 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:28.668526 [ 2825 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:28.699343 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:28.876908 [ 3102 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:28.950778 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:29.032302 [ 3136 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): We have part -2_58_124_1 covering part -2_58_58_0, will not check 2025.06.12 19:09:29.185222 [ 2982 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:29.321049 [ 3103 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): We have part -2_58_124_1 covering part -2_58_58_0, will not check 2025.06.12 19:09:29.476455 [ 3160 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:29.553167 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:29.669472 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:29.773038 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:29.877885 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:30.142139 [ 31230 ] {4e308bcb-2775-4b84-b35c-91c9406b9c0d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34974) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:30.143704 [ 31230 ] {4e308bcb-2775-4b84-b35c-91c9406b9c0d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:30.186126 [ 3194 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:30.409182 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:30.477146 [ 2804 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:30.593088 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:30.670144 [ 2752 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:30.975373 [ 2813 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:31.187008 [ 2801 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:31.249968 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:31.455196 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:31.477999 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:31.587321 [ 31230 ] {ef3ddfd1-1792-43cb-93a4-af53944a46e4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35034) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:31.588524 [ 31230 ] {ef3ddfd1-1792-43cb-93a4-af53944a46e4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:31.670894 [ 3068 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:32.042997 [ 2759 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:32.109849 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:32.188050 [ 2728 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:32.281891 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:32.488949 [ 3097 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:32.672017 [ 3061 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:32.830663 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a7456aa7-856d-4768-8b2f-dc442b5d1136::202506_135_268_17}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:32.953382 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:33.043978 [ 2706 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:33.048738 [ 31230 ] {46962579-565e-4979-ab22-800c8b51a0dd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53648) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:33.050184 [ 31230 ] {46962579-565e-4979-ab22-800c8b51a0dd} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:33.127305 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:33.189062 [ 3006 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:33.489837 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:33.673062 [ 2955 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:33.795750 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:33.955983 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:34.044668 [ 2718 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:34.190241 [ 2740 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:34.490950 [ 2763 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:34.562421 [ 31230 ] {2a4b3ec5-d02a-4763-a67f-9a97edfee2ee} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53668) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:34.563678 [ 31230 ] {2a4b3ec5-d02a-4763-a67f-9a97edfee2ee} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:34.623477 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:34.673825 [ 2831 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:34.706974 [ 2875 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part 9_0_95_2 covering part 9_72_72_0, will not check 2025.06.12 19:09:34.798678 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:35.045535 [ 2941 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:35.191344 [ 2863 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:35.492024 [ 3072 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:35.526146 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:35.674868 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:35.694744 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:36.067682 [ 3115 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:36.192123 [ 3096 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:36.274908 [ 31230 ] {e7e37d54-41e7-47f5-8a27-808605f1faae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53720) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:36.276051 [ 31230 ] {e7e37d54-41e7-47f5-8a27-808605f1faae} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:36.368601 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:36.492901 [ 2700 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:36.580916 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:36.675996 [ 3030 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:37.068675 [ 2694 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:37.192928 [ 3119 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:37.198687 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:37.426069 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:37.493628 [ 2841 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:37.676792 [ 2955 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:37.805416 [ 31230 ] {8aff73ba-781c-40cd-b230-f6b117baa431} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53766) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:37.809303 [ 31230 ] {8aff73ba-781c-40cd-b230-f6b117baa431} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:38.060534 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:38.069458 [ 2917 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:38.194042 [ 2856 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:38.251994 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:38.494300 [ 2858 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:38.677841 [ 2815 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:38.947241 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:39.070218 [ 3150 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:39.104520 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:39.194972 [ 3179 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:39.269372 [ 31230 ] {2205213e-8fa6-49a5-9e3b-e7ca96ef3627} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53816) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:39.270501 [ 31230 ] {2205213e-8fa6-49a5-9e3b-e7ca96ef3627} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:39.495267 [ 2817 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:39.679090 [ 2711 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:39.832627 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:39.955218 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:40.070907 [ 3034 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:40.195926 [ 2953 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:40.497510 [ 3074 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:40.673824 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:40.680494 [ 3028 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:40.799227 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:40.861586 [ 31269 ] {dd56b07c-f60f-4d98-b61b-9896f5e168f9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53866) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:40.862941 [ 31269 ] {dd56b07c-f60f-4d98-b61b-9896f5e168f9} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:41.072197 [ 3044 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:41.196971 [ 2779 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:41.418960 [ 2961 ] {} test_9.alter_table_0 (ReplicatedMergeTreePartCheckThread): We have part 8_76_124_1 covering part 8_76_76_0, will not check 2025.06.12 19:09:41.419107 [ 3009 ] {} test_9.alter_table_4 (ReplicatedMergeTreePartCheckThread): We have part 8_76_124_1 covering part 8_76_76_0, will not check 2025.06.12 19:09:41.419260 [ 2692 ] {} test_9.alter_table_8 (ReplicatedMergeTreePartCheckThread): We have part 8_76_124_1 covering part 8_76_76_0, will not check 2025.06.12 19:09:41.419362 [ 2885 ] {} test_9.alter_table_9 (ReplicatedMergeTreePartCheckThread): We have part 8_76_124_1 covering part 8_76_76_0, will not check 2025.06.12 19:09:41.419527 [ 2797 ] {} test_9.alter_table_1 (ReplicatedMergeTreePartCheckThread): We have part 8_76_124_1 covering part 8_76_76_0, will not check 2025.06.12 19:09:41.498897 [ 2966 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:41.518209 [ 3004 ] {} test_9.alter_table_7 (ReplicatedMergeTreePartCheckThread): We have part 8_76_124_1 covering part 8_76_76_0, will not check 2025.06.12 19:09:41.539246 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:41.653363 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:41.681645 [ 3100 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:42.073222 [ 2757 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:42.197848 [ 2965 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:42.366257 [ 31230 ] {9f8c99b8-10b6-4bef-a67f-f8ac13a37325} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37320) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:42.369199 [ 31230 ] {9f8c99b8-10b6-4bef-a67f-f8ac13a37325} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:42.499850 [ 2960 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:42.534968 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:42.609061 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:42.682848 [ 3172 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:43.074465 [ 3058 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:43.198653 [ 3183 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:43.413269 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:43.462863 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:43.500957 [ 2688 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:43.684059 [ 3068 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:43.810354 [ 31230 ] {9488b115-3d10-4254-ab2c-0cab9f1c6d7f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37380) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:43.811723 [ 31230 ] {9488b115-3d10-4254-ab2c-0cab9f1c6d7f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:44.075601 [ 2925 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:44.199592 [ 2927 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:44.279790 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:44.306987 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:44.501968 [ 2722 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:44.684972 [ 3087 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.076516 [ 3133 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.126261 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:45.131907 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:45.200698 [ 3028 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.276803 [ 3001 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.276993 [ 2970 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.277022 [ 3178 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.277343 [ 2724 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.277740 [ 2802 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.278322 [ 3136 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.278850 [ 3065 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.341931 [ 3003 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.342548 [ 2942 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.342571 [ 3108 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.342880 [ 3005 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.342956 [ 2812 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.343260 [ 2735 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.343679 [ 3149 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.345262 [ 3073 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.345328 [ 2938 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.345540 [ 2795 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.345940 [ 3044 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.346185 [ 2700 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.346460 [ 2728 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.347351 [ 3097 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.347851 [ 3061 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.348033 [ 3155 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:45.349119 [ 2924 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.349219 [ 2886 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.349245 [ 3032 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.391359 [ 31230 ] {6698a0ca-d99a-46ea-b93f-a49eddcd4c14} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37436) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:45.393227 [ 31230 ] {6698a0ca-d99a-46ea-b93f-a49eddcd4c14} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:45.443620 [ 3177 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.475624 [ 2727 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.514624 [ 2778 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.532552 [ 3148 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:45.685776 [ 2791 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.005931 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:46.006756 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:46.077244 [ 3123 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.201414 [ 2984 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.533404 [ 2974 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.686726 [ 2931 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.851501 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:46.854511 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:46.864349 [ 17157 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.865043 [ 2944 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.865204 [ 3008 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.865384 [ 2803 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.865527 [ 3112 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.865864 [ 3186 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.866013 [ 2747 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.866161 [ 2725 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.866524 [ 3086 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.866822 [ 3000 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.866998 [ 2821 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.867293 [ 2832 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.867872 [ 2688 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.867972 [ 3115 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.868019 [ 3117 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.868260 [ 2703 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.868861 [ 3068 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.869008 [ 2697 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.869328 [ 3140 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.869532 [ 3152 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.869719 [ 3151 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.870322 [ 2963 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.870497 [ 2953 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:46.871267 [ 3130 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.871367 [ 3056 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.871543 [ 2909 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.871571 [ 2765 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.874592 [ 2765 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.943041 [ 2948 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:46.943066 [ 3079 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:47.038447 [ 31230 ] {0ee008d7-a472-4d3f-9f89-2909b807aee3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37464) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:47.040068 [ 31230 ] {0ee008d7-a472-4d3f-9f89-2909b807aee3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:47.078915 [ 2716 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:47.202206 [ 2723 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:47.204227 [ 3125 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:47.205990 [ 3125 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:47.534284 [ 2818 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:47.689540 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:47.736059 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:47.736082 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:48.080223 [ 2826 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:48.203045 [ 3109 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:48.535181 [ 2858 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:48.569767 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:48.623777 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:48.690848 [ 2844 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:48.783358 [ 31230 ] {eaeda674-d5b4-49ff-a520-ec53cebfa66a} 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.10057.altinitytest (altinity build)) (from [::1]:37500) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:48.785397 [ 31230 ] {eaeda674-d5b4-49ff-a520-ec53cebfa66a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:49.081276 [ 2794 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:49.203870 [ 3067 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:49.428292 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:49.475603 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:49.536026 [ 3165 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:49.692008 [ 2980 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:50.082294 [ 2695 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:50.204782 [ 2945 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:50.272892 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:50.323983 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:50.331437 [ 31230 ] {ffd6cde9-d715-4440-a57f-67f159843876} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37542) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:50.332682 [ 31230 ] {ffd6cde9-d715-4440-a57f-67f159843876} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:50.536856 [ 3171 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:50.693052 [ 3057 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:51.083328 [ 3044 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:51.114187 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:51.152246 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:51.205595 [ 3003 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:51.537656 [ 2778 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:51.694004 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:51.945240 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:51.997599 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:52.084061 [ 2826 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:52.206367 [ 2962 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:52.256641 [ 31230 ] {a02cc92e-ed31-44e7-a66c-0423bfb2e246} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37582) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:52.257721 [ 31230 ] {a02cc92e-ed31-44e7-a66c-0423bfb2e246} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:52.538870 [ 2804 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:52.695064 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:52.784893 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:52.823971 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:53.084872 [ 2805 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:53.207465 [ 3067 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:53.539695 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:53.675741 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:53.695742 [ 3052 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:53.703193 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:54.085752 [ 2732 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:54.208536 [ 2986 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:54.540509 [ 3187 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:54.542671 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:54.558975 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:54.696424 [ 3176 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:54.854134 [ 23467 ] {87989d5f-b331-4130-b156-756f9bb53572} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/-1_0_126_2_124/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 0 with max_rows_to_read = 40131): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47078) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a954baa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:09:54.890668 [ 23467 ] {87989d5f-b331-4130-b156-756f9bb53572} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/-1_0_126_2_124/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 0 with max_rows_to_read = 40131): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a954baa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:09:55.086835 [ 3057 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.209561 [ 3044 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.337583 [ 5641 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.338454 [ 3122 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.338793 [ 2830 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.339035 [ 3038 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.339367 [ 2832 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.339895 [ 2971 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.340169 [ 2955 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.340467 [ 2819 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.340597 [ 3003 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.340868 [ 2961 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.341498 [ 2723 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.341532 [ 3071 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.341794 [ 2879 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.342111 [ 2865 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.342567 [ 3134 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.342869 [ 3125 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.343055 [ 3182 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.343434 [ 2715 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.343769 [ 2812 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.344126 [ 3128 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.344265 [ 2919 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.344903 [ 3155 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.345150 [ 3103 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:09:55.346023 [ 2716 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.346064 [ 2713 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.346113 [ 3100 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.346061 [ 3004 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.346059 [ 3129 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.346110 [ 3160 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.347674 [ 3129 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.412148 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:55.413918 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:55.442627 [ 3196 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.541415 [ 2837 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:55.743528 [ 2777 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:56.088140 [ 2702 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:56.210465 [ 2806 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:56.269232 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:56.325752 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:56.488289 [ 23927 ] {32db704b-7c90-4357-866f-f70fef25bda5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47148) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:56.489748 [ 23927 ] {32db704b-7c90-4357-866f-f70fef25bda5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:56.542261 [ 2851 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:56.744945 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:57.089215 [ 2835 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:57.104305 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:57.183696 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:57.211538 [ 3049 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:57.543263 [ 2975 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:57.745800 [ 3072 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:57.937975 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:57.941576 [ 23927 ] {5ebdd78b-5d03-4b8d-97b0-57a7914251f7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47182) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:57.943361 [ 23927 ] {5ebdd78b-5d03-4b8d-97b0-57a7914251f7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:58.090236 [ 2904 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:58.099158 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:58.212565 [ 2986 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:58.544070 [ 2747 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:58.746965 [ 2779 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:58.796634 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:58.934443 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:59.106457 [ 3086 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:59.213429 [ 3124 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:59.406131 [ 23927 ] {bae7411b-77de-42c9-9282-a54787eb9ab4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47226) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:59.407274 [ 23927 ] {bae7411b-77de-42c9-9282-a54787eb9ab4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:59.544968 [ 3121 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:59.639311 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:09:59.756564 [ 2728 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:09:59.767541 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:00.199199 [ 3027 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:00.214260 [ 2966 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:00.469559 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:00.545832 [ 2884 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:00.633308 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:00.757493 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.200059 [ 3172 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.215206 [ 3158 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.252773 [ 2873 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.253003 [ 3174 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.253125 [ 2794 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.253315 [ 3053 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.253725 [ 2790 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.253998 [ 2984 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.254219 [ 2743 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.254438 [ 3067 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.254793 [ 2748 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.274026 [ 2704 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.298072 [ 2828 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.298829 [ 3179 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.299212 [ 2768 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.299744 [ 2872 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.300228 [ 2857 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.300550 [ 2863 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.300707 [ 3110 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.301045 [ 2751 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.301238 [ 3105 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.301548 [ 2813 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.301771 [ 3092 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.302228 [ 2898 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.302535 [ 2702 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:01.303828 [ 2899 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.304044 [ 2752 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.304060 [ 2766 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.304586 [ 3036 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.306206 [ 2913 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.331311 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:01.342235 [ 23927 ] {1ec33b0c-2dc1-46ad-9512-c912ca4857f9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47268) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:01.362527 [ 23467 ] {bc4cd820-203e-49d3-952d-50718b4722db} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:47272) (comment: 00572_aggregation_by_empty_set.sql) (in query: SELECT x, count(), uniq(x), avg(x), avg(toNullable(x)), groupArray(x), groupUniqArray(x) FROM t GROUP 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:01.363893 [ 23467 ] {bc4cd820-203e-49d3-952d-50718b4722db} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:01.385644 [ 23927 ] {1ec33b0c-2dc1-46ad-9512-c912ca4857f9} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:01.466538 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:01.546992 [ 2688 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.576032 [ 2763 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:01.758253 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:02.163294 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:02.200876 [ 2930 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:02.215928 [ 2785 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:02.297281 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:02.547968 [ 2978 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:02.759125 [ 3154 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:03.006648 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:03.117627 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:03.201494 [ 2947 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:03.216570 [ 2903 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:03.549823 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:03.760350 [ 2961 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:03.850356 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:03.943132 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:03.975956 [ 23467 ] {9280aa70-f588-4ab2-b2cd-7b8abdebb124} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/38b/38b1b594-8cf2-483c-bb28-07c4a85bce95/-2_0_57_1_122/ in table test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95) located on disk default of type local, from mark 2 with max_rows_to_read = 22304): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57012) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a954baa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:10:04.055512 [ 23467 ] {9280aa70-f588-4ab2-b2cd-7b8abdebb124} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/38b/38b1b594-8cf2-483c-bb28-07c4a85bce95/-2_0_57_1_122/ in table test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95) located on disk default of type local, from mark 2 with max_rows_to_read = 22304): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a954baa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:10:04.202720 [ 3184 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:04.217488 [ 2704 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:04.550896 [ 2743 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:04.685534 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:04.761167 [ 2922 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:04.769457 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:05.203881 [ 2756 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:05.218304 [ 2751 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:05.473885 [ 23467 ] {be84bc93-e10d-4a62-ba41-3c42553a075e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57076) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:05.475092 [ 23467 ] {be84bc93-e10d-4a62-ba41-3c42553a075e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:05.519323 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:05.613694 [ 2995 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:05.621208 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:05.761914 [ 3023 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:06.204862 [ 3096 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:06.219305 [ 2873 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:06.365897 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:06.451711 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:06.614688 [ 2808 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:06.727035 [ 23927 ] {1bf4aebf-1f15-4ff8-858a-3c8922cb092a} executeQuery: Code: 36. DB::Exception: Only `Float64` data type is allowed for the value column of GraphiteMergeTree. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57098) (comment: 02508_bad_graphite.sql) (in query: INSERT INTO test_graphite (key) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Processors/Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp:36: DB::GraphiteRollupSortedAlgorithm::GraphiteRollupSortedAlgorithm(DB::Block const&, unsigned long, DB::SortDescription, unsigned long, unsigned long, DB::Graphite::Params, long) @ 0x000000001a7f1692 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::GraphiteRollupSortedAlgorithm* std::construct_at[abi:v15007](DB::GraphiteRollupSortedAlgorithm*, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x0000000019cd9590 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000019ccbd3c 7. ./contrib/llvm-project/libcxx/include/vector:1348: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cce63f 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 18. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 19. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:06.727910 [ 23927 ] {1bf4aebf-1f15-4ff8-858a-3c8922cb092a} TCPHandler: Code: 36. DB::Exception: Only `Float64` data type is allowed for the value column of GraphiteMergeTree. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Processors/Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp:36: DB::GraphiteRollupSortedAlgorithm::GraphiteRollupSortedAlgorithm(DB::Block const&, unsigned long, DB::SortDescription, unsigned long, unsigned long, DB::Graphite::Params, long) @ 0x000000001a7f1692 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::GraphiteRollupSortedAlgorithm* std::construct_at[abi:v15007](DB::GraphiteRollupSortedAlgorithm*, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x0000000019cd9590 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000019ccbd3c 7. ./contrib/llvm-project/libcxx/include/vector:1348: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cce63f 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cccdf2 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e8f3fc 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7cb64d 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a693566 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6932d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a692bd5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a2fb7ec 18. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1e57fe 19. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1d8f7e 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 26. __tsan_thread_start_func @ 0x000000000758af2f 27. ? @ 0x00007f4e69e13ac3 28. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:06.762855 [ 3108 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:06.922971 [ 23467 ] {863f2c6e-74ff-4eb6-bbc0-2ca1bdfe3d63} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57144) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:06.924103 [ 23467 ] {863f2c6e-74ff-4eb6-bbc0-2ca1bdfe3d63} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:07.203196 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:07.205682 [ 3100 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.220137 [ 3044 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.307918 [ 23467 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:07.469358 [ 30749 ] {74035ae0-c792-47f2-9432-1e1fd270be3a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44454) (comment: 03043_group_array_result_is_expected.sql) (in query: DROP DATABASE IF EXISTS test_s3os7rye ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:07.470293 [ 30749 ] {74035ae0-c792-47f2-9432-1e1fd270be3a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.615331 [ 2968 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.763783 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.870642 [ 17153 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.871420 [ 2942 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.871584 [ 2895 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.871767 [ 2947 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.872049 [ 3046 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.872360 [ 3157 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.872540 [ 2848 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.872693 [ 2838 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.872907 [ 3169 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.873130 [ 2861 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.873398 [ 3196 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.873828 [ 2723 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.873927 [ 2928 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.874291 [ 3016 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.874575 [ 2887 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.874793 [ 2957 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.874967 [ 2849 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.875482 [ 2800 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.875418 [ 2871 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.875907 [ 2870 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.875919 [ 2970 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.876509 [ 2884 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.876723 [ 2842 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:07.877765 [ 3156 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.877804 [ 2981 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.877951 [ 2937 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.877971 [ 2850 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.878034 [ 2804 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.877956 [ 2811 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.878437 [ 2712 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.878818 [ 2992 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:07.961895 [ 2735 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.042027 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:08.133069 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:08.206297 [ 3084 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.220898 [ 2810 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.257988 [ 3126 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.258102 [ 3011 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.258242 [ 2732 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.258302 [ 2683 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.259002 [ 3050 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.259149 [ 2920 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.259283 [ 3028 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.259415 [ 3023 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.259741 [ 2909 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.259888 [ 3087 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.260065 [ 2695 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.260269 [ 3090 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.260492 [ 3105 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.260661 [ 2710 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.260794 [ 2931 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.260974 [ 2719 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.261098 [ 2821 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.261250 [ 2769 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.261382 [ 3018 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.261663 [ 2977 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.261946 [ 2750 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.262136 [ 2907 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:08.262869 [ 3170 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264074 [ 2872 ] {} test_9.quorum1 (e4e2b33f-3d2d-459e-8d1e-407a5c530dcb): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/replicas/1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264133 [ 2851 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264204 [ 3049 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264393 [ 2900 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264143 [ 3130 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264111 [ 2753 ] {} test_9.clear_column1 (b3a76e2b-dbbf-4574-980d-021aec1f5b11): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264641 [ 2863 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264694 [ 2922 ] {} test_9.rep_data (843bbcbe-99b5-42d1-85b3-eed8ef79861a): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cf7ec 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264732 [ 2919 ] {} test_9.rep_data (843bbcbe-99b5-42d1-85b3-eed8ef79861a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/rep_data/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264980 [ 3165 ] {} test_9.clear_column1 (b3a76e2b-dbbf-4574-980d-021aec1f5b11): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cf7ec 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.264981 [ 3013 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.265240 [ 2837 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.265272 [ 2835 ] {} test_9.quorum1 (e4e2b33f-3d2d-459e-8d1e-407a5c530dcb): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.265360 [ 2777 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.265368 [ 2752 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.265484 [ 2783 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.265453 [ 2925 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.265891 [ 2699 ] {} test_9.clear_column2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.265940 [ 3152 ] {} test_9.clear_column1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266160 [ 2803 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266175 [ 2839 ] {} test_9.quorum1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266280 [ 2698 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266527 [ 2705 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266678 [ 2831 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266868 [ 3033 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/data/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266879 [ 2788 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266961 [ 3006 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/mutations. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d824d7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.266881 [ 3072 ] {} test_15.data_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/data/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.267188 [ 3139 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cf7ec 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.267554 [ 2979 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.267976 [ 3069 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268094 [ 3052 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268193 [ 2975 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268191 [ 3054 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268288 [ 2737 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268258 [ 3183 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268361 [ 2847 ] {} test_9.rep_data (843bbcbe-99b5-42d1-85b3-eed8ef79861a): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268598 [ 2927 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268614 [ 2945 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.268918 [ 3137 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.269184 [ 3092 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.269262 [ 2745 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019dac74d 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000019da1791 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000193cf7ec 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf82 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.269663 [ 3144 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.273321 [ 3014 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.273421 [ 3006 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.273562 [ 3115 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.273968 [ 3188 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.454739 [ 3045 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.454830 [ 3015 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.454864 [ 2823 ] {} test_9.clear_column1 (b3a76e2b-dbbf-4574-980d-021aec1f5b11): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.468479 [ 2921 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.480877 [ 2857 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.480875 [ 3039 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.481012 [ 2994 ] {} test_9.rep_data (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/rep_data/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.480976 [ 3172 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.480997 [ 2806 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.482766 [ 2806 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.482984 [ 3167 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.616246 [ 3086 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.764503 [ 2962 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.857596 [ 23467 ] {6b08ba92-f3e5-4a7b-98a3-b6eb843810e6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44492) (comment: 01548_lzy305.sql) (in query: DROP DATABASE IF EXISTS test_zfkxko6p ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:08.858378 [ 23467 ] {6b08ba92-f3e5-4a7b-98a3-b6eb843810e6} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.863730 [ 29580 ] {7a63ff6e-f4a0-415d-a579-7a1a7bd0f3a7} 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.10057.altinitytest (altinity build)) (from [::1]:57222) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:08.864983 [ 31184 ] {7bdfb432-8544-4423-9a67-b8a6091d7cc3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44494) (comment: 01548_lzy305.sql) (in query: DROP DATABASE IF EXISTS test_zfkxko6p ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:08.865034 [ 29580 ] {7a63ff6e-f4a0-415d-a579-7a1a7bd0f3a7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:08.865764 [ 31184 ] {7bdfb432-8544-4423-9a67-b8a6091d7cc3} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:08.886767 [ 29533 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:08.958678 [ 29533 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:09.207250 [ 3037 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:09.221592 [ 2791 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:09.423260 [ 29533 ] {97b9c2b9-c346-4f30-b0f7-24888297dec9} executeQuery: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 18446744073709551615): While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57250) (comment: 02874_analysis_of_variance_overflow.sql) (in query: SELECT analysisOfVariance(1, 18446744073709551615);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000007641b06 4. ./src/AggregateFunctions/Moments.h:463: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x0000000015d37449 5. ./src/AggregateFunctions/IAggregateFunction.h:530: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000015d352f7 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000017742543 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1463: 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 @ 0x000000001774500e 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001a65e8fe 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::AggregatingTransform::work() @ 0x000000001a65aab3 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:09.424071 [ 29533 ] {97b9c2b9-c346-4f30-b0f7-24888297dec9} TCPHandler: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 18446744073709551615): While executing AggregatingTransform. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000007641b06 4. ./src/AggregateFunctions/Moments.h:463: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x0000000015d37449 5. ./src/AggregateFunctions/IAggregateFunction.h:530: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000015d352f7 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000017742543 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1463: 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 @ 0x000000001774500e 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001a65e8fe 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::AggregatingTransform::work() @ 0x000000001a65aab3 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:09.617095 [ 3123 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:09.721634 [ 29533 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:09.765317 [ 2834 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:09.804796 [ 29533 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:10.207971 [ 2734 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:10.222236 [ 3184 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:10.376563 [ 29533 ] {4971f016-75d9-4400-b2b9-484e2fbf57ed} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57278) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:10.377692 [ 29533 ] {4971f016-75d9-4400-b2b9-484e2fbf57ed} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:10.569640 [ 29533 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:10.617774 [ 3145 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:10.637941 [ 29580 ] {60f4632b-cc9a-42f8-af00-43e1dd61b58e} executeQuery: Code: 57. DB::Exception: Table test_qzcm2ig1.ts already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57288) (comment: 02730_with_fill_by_sorting_prefix.sql) (in query: CREATE TABLE ts (`sensor_id` UInt64, `timestamp` UInt64, `value` Float64) ENGINE = MergeTree ORDER BY (sensor_id, timestamp) SETTINGS index_granularity = 1407, min_bytes_for_wide_part = 658662721, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 26, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 93711140, compact_parts_max_granules_to_buffer = 217, compact_parts_merge_max_bytes_to_prefetch_part = 22773693, merge_max_block_size = 6083, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 911957, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 30112615, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 41561, primary_key_compress_block_size = 22652), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:10.638448 [ 29580 ] {60f4632b-cc9a-42f8-af00-43e1dd61b58e} TCPHandler: Code: 57. DB::Exception: Table test_qzcm2ig1.ts already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:10.639749 [ 29533 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:10.766187 [ 2749 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:11.209380 [ 2768 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:11.223136 [ 2900 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:11.412564 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:11.467971 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:11.618565 [ 2747 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:11.767142 [ 2873 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:11.835559 [ 29580 ] {383d0127-2b5a-4975-a4db-fb11101119aa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57348) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:11.837149 [ 29580 ] {383d0127-2b5a-4975-a4db-fb11101119aa} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:12.210279 [ 2790 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:12.224010 [ 2694 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:12.241012 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:12.294059 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:12.619321 [ 2724 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:12.768068 [ 2802 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:13.090710 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:13.118953 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:13.211270 [ 3121 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:13.224976 [ 2719 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:13.538925 [ 29580 ] {9a113b57-d6de-4215-83e2-cbee289990e8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59992) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:13.541775 [ 29580 ] {9a113b57-d6de-4215-83e2-cbee289990e8} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:13.620417 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:13.769300 [ 2937 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:13.939820 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:14.046221 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:14.212129 [ 2960 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:14.225886 [ 3037 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:14.621464 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:14.765907 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:14.770151 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:14.866939 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:15.213394 [ 2867 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.226910 [ 2739 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.315424 [ 2936 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.315461 [ 2849 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.316473 [ 2793 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.316568 [ 3181 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.320752 [ 2964 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.321305 [ 2749 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.321605 [ 2723 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.322022 [ 2693 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.322560 [ 2686 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.322856 [ 2933 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.323317 [ 2883 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.324240 [ 2756 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.324282 [ 3141 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.324493 [ 3034 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.324797 [ 2722 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.325019 [ 2829 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.326106 [ 2884 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.326054 [ 3017 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.326443 [ 2746 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.327051 [ 2898 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.327292 [ 2901 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.327663 [ 2934 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.328189 [ 2942 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.328447 [ 2711 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:15.329281 [ 3067 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.329333 [ 2765 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.329584 [ 3145 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.330214 [ 2708 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.330398 [ 3043 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.331138 [ 3189 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.331219 [ 3056 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.331298 [ 2765 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.345004 [ 29580 ] {963742ca-71c1-438e-9e2d-6f05dba4f04a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60018) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:15.348912 [ 29580 ] {963742ca-71c1-438e-9e2d-6f05dba4f04a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:15.388544 [ 2980 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.560928 [ 2809 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.595123 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:15.622274 [ 2904 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:15.696269 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:15.705094 [ 29533 ] {175ab324-912d-4991-9fe8-d13a4151fae3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57324) (comment: 02714_read_bytes_aggregateFunction.sql) (in query: SELECT 'UInt64', read_rows, read_bytes FROM system.query_log WHERE current_database = currentDatabase() AND query = 'SELECT sum(id) FROM test FORMAT Null;' AND type = 2 AND event_date >= yesterday() ORDER BY event_time_microseconds;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a974a86 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:15.707610 [ 29533 ] {175ab324-912d-4991-9fe8-d13a4151fae3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a974a86 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:15.799307 [ 3167 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:16.214242 [ 2889 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:16.227585 [ 2897 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:16.413525 [ 29580 ] {030a4a5f-4527-4b89-b60e-6d80615d94a9} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('[42]', 'Array(LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select [42]::Array(LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:16.414176 [ 29580 ] {030a4a5f-4527-4b89-b60e-6d80615d94a9} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('[42]', 'Array(LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:16.425891 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:16.538921 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:16.623495 [ 2914 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:16.717407 [ 29580 ] {3366d1aa-588f-4c49-8785-5d50e5592233} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select [[[42]]]::Array(Array(Array(LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:16.718011 [ 29580 ] {3366d1aa-588f-4c49-8785-5d50e5592233} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:16.799971 [ 2882 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:16.847256 [ 4083 ] {0423da7e-daad-4687-a10a-c983bbd8ef06} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60082) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:16.848518 [ 4083 ] {0423da7e-daad-4687-a10a-c983bbd8ef06} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:16.899373 [ 29580 ] {b5b4912c-354c-437a-a52d-af5762e18878} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(map('a', 42), 'Map(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select map('a', 42)::Map(String, LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:16.900151 [ 29580 ] {b5b4912c-354c-437a-a52d-af5762e18878} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(map('a', 42), 'Map(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:17.215061 [ 3097 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:17.228279 [ 2735 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:17.254868 [ 29580 ] {b3b54513-f2f5-48bb-b103-be067b6c600d} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select map('a', map('b', [42]))::Map(String, Map(String, Array(LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:17.255491 [ 29580 ] {b3b54513-f2f5-48bb-b103-be067b6c600d} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:17.326818 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:17.382646 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:17.433203 [ 29580 ] {f4d9de0f-5e0f-4613-89fc-a7ee0c333ca3} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', 42), 'Tuple(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', 42)::Tuple(String, LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:17.433905 [ 29580 ] {f4d9de0f-5e0f-4613-89fc-a7ee0c333ca3} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', 42), 'Tuple(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:17.624272 [ 3046 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:17.760000 [ 29580 ] {34e5ad6b-c1f1-46a2-a087-f025b686fccc} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:17.760725 [ 29580 ] {34e5ad6b-c1f1-46a2-a087-f025b686fccc} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:17.800682 [ 3138 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:17.851869 [ 29580 ] {15be190e-0fd6-42e0-a088-2a94db2263b0} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:17.852513 [ 29580 ] {15be190e-0fd6-42e0-a088-2a94db2263b0} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:17.955661 [ 29580 ] {a6023ce0-d8c0-41d6-8edb-687b2c129fe2} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(Array(LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:17.956372 [ 29580 ] {a6023ce0-d8c0-41d6-8edb-687b2c129fe2} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.162308 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.210429 [ 29580 ] {a8eb36ba-1dce-484c-b87c-69ecc2407f07} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.211177 [ 29580 ] {a8eb36ba-1dce-484c-b87c-69ecc2407f07} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.215897 [ 3182 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:18.219463 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.229147 [ 2767 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:18.300998 [ 4083 ] {96262793-35bd-4690-aeb5-06cc0acf4366} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60130) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.301903 [ 4083 ] {96262793-35bd-4690-aeb5-06cc0acf4366} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.405944 [ 29580 ] {e7106a23-c0bc-4bf5-a385-18cf97b6e67e} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, Map(String, LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.411880 [ 29580 ] {e7106a23-c0bc-4bf5-a385-18cf97b6e67e} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.624979 [ 2831 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:18.652737 [ 29580 ] {93334844-3d78-478f-bbe7-82a340a141ec} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.653462 [ 29580 ] {93334844-3d78-478f-bbe7-82a340a141ec} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.758786 [ 29580 ] {c000b6f7-37be-45a1-8ba9-a1b9e7d7e978} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, LowCardinality(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.760712 [ 29580 ] {c000b6f7-37be-45a1-8ba9-a1b9e7d7e978} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:18.801413 [ 2746 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:18.931800 [ 29580 ] {3a7dc89f-5c07-4f41-8f26-1fcf8023b007} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select ['42']::Array(FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:18.932505 [ 29580 ] {3a7dc89f-5c07-4f41-8f26-1fcf8023b007} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[\'42\']', 'Array(FixedString(1000000))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:18.939682 [ 29580 ] {4f482d74-edab-4d4f-9d86-798c37342a88} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select ['42']::Array(FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:18.940202 [ 29580 ] {4f482d74-edab-4d4f-9d86-798c37342a88} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[\'42\']', 'Array(FixedString(1000000))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:19.012907 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:19.049196 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:19.061533 [ 29580 ] {6524c952-f6f5-449c-ae78-5a091eeef276} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[[[\'42\']]]', 'Array(Array(Array(FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select [[['42']]]::Array(Array(Array(FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:19.062092 [ 29580 ] {6524c952-f6f5-449c-ae78-5a091eeef276} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[[[\'42\']]]', 'Array(Array(Array(FixedString(1000000))))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:19.216515 [ 3112 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:19.229750 [ 2976 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:19.338653 [ 29580 ] {9412b2eb-851f-420d-b761-188e1a682105} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(map('a', '42'), 'Map(String, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select map('a', '42')::Map(String, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:19.339526 [ 29580 ] {9412b2eb-851f-420d-b761-188e1a682105} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(map('a', '42'), 'Map(String, FixedString(1000000))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:19.576076 [ 29580 ] {bfddc2bc-3043-4753-a4fc-2fb7d3a4c643} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', ['42'])), 'Map(String, Map(String, Array(FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select map('a', map('b', ['42']))::Map(String, Map(String, Array(FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:19.576741 [ 29580 ] {bfddc2bc-3043-4753-a4fc-2fb7d3a4c643} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', ['42'])), 'Map(String, Map(String, Array(FixedString(1000000))))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:19.625658 [ 2983 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:19.803472 [ 3064 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:19.855209 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:19.895542 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:19.951914 [ 29580 ] {758ec86d-9a5d-4ee9-a73d-df7aed4b629a} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', '42'), 'Tuple(String, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', '42')::Tuple(String, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:19.953579 [ 29580 ] {758ec86d-9a5d-4ee9-a73d-df7aed4b629a} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', '42'), 'Tuple(String, FixedString(1000000))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:20.186075 [ 29580 ] {545fd055-6521-41b5-961f-1939faa454c6} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', '42')])::Tuple(String, Array(Map(String, FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:20.187055 [ 29580 ] {545fd055-6521-41b5-961f-1939faa454c6} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, FixedString(1000000))))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:20.192998 [ 4083 ] {1c12f744-56d6-45a3-8718-ba991c342cb1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60146) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:20.194271 [ 4083 ] {1c12f744-56d6-45a3-8718-ba991c342cb1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:20.217452 [ 2790 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:20.231176 [ 2934 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:20.348975 [ 29580 ] {70219140-3897-4052-8911-903c6ede6173} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(FixedString(1000000))) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:20.415420 [ 29580 ] {70219140-3897-4052-8911-903c6ede6173} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:20.626450 [ 2885 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:20.712009 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:20.717548 [ 29580 ] {a74e0300-a498-4316-a277-60b89606e819} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(Array(FixedString(1000000)))) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:20.718120 [ 29580 ] {a74e0300-a498-4316-a277-60b89606e819} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:20.733678 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:20.804525 [ 2910 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:21.165750 [ 29580 ] {89ed17f0-6f2b-48bc-942e-e306bb4ba71d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, FixedString(1000000))) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.166315 [ 29580 ] {89ed17f0-6f2b-48bc-942e-e306bb4ba71d} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.218321 [ 2684 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:21.232086 [ 2914 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:21.389389 [ 29580 ] {c1338189-7b3b-453f-9acd-3d97c6ae810f} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, Map(String, FixedString(1000000)))) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.390114 [ 29580 ] {c1338189-7b3b-453f-9acd-3d97c6ae810f} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.562845 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.565262 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.605607 [ 29580 ] {7fd17759-d437-4b76-87f0-39720faecf5c} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, FixedString(1000000))) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.606602 [ 29580 ] {7fd17759-d437-4b76-87f0-39720faecf5c} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.664921 [ 3094 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:21.795192 [ 29580 ] {0a5a0803-997a-448f-bd52-c958fa0efe82} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, FixedString(1000000))))) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.795952 [ 29580 ] {0a5a0803-997a-448f-bd52-c958fa0efe82} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:21.805477 [ 2877 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:22.018690 [ 29580 ] {046ff47a-651c-4800-9253-4461d14e91ef} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[42]', 'Array(Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select [42]::Array(Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:22.019411 [ 29580 ] {046ff47a-651c-4800-9253-4461d14e91ef} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[42]', 'Array(Variant(String, UInt64))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:22.047400 [ 4083 ] {c0d2674b-8cd8-4b42-9b39-0646bf8fbb83} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60218) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:22.048546 [ 4083 ] {c0d2674b-8cd8-4b42-9b39-0646bf8fbb83} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:22.219103 [ 2820 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:22.232817 [ 2776 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:22.336234 [ 29580 ] {2c853bbe-da1a-4edf-8479-68f25d76f9b6} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select [[[42]]]::Array(Array(Array(Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:22.337047 [ 29580 ] {2c853bbe-da1a-4edf-8479-68f25d76f9b6} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(Variant(String, UInt64))))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:22.396310 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:22.489935 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:22.665964 [ 2887 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:22.786006 [ 29580 ] {959c207a-03bc-476f-ba6c-697d71bc6e09} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', 42), 'Map(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select map('a', 42)::Map(String, Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:22.787085 [ 29580 ] {959c207a-03bc-476f-ba6c-697d71bc6e09} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', 42), 'Map(String, Variant(String, UInt64))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:22.806392 [ 3168 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:23.043161 [ 29580 ] {de17eb07-c9a1-4da8-abde-7029d2403569} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select map('a', map('b', [42]))::Map(String, Map(String, Array(Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:23.043824 [ 29580 ] {de17eb07-c9a1-4da8-abde-7029d2403569} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(Variant(String, UInt64))))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:23.219970 [ 3164 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:23.221796 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:23.233622 [ 2799 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:23.315894 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:23.325441 [ 29580 ] {dc193d61-36bb-4124-86ac-d741b4a33fc5} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', 42), 'Tuple(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', 42)::Tuple(String, Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:23.326540 [ 29580 ] {dc193d61-36bb-4124-86ac-d741b4a33fc5} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', 42), 'Tuple(String, Variant(String, UInt64))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:23.582334 [ 29580 ] {741228af-8b7b-4616-94f8-a70b2cc17237} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:23.583893 [ 29580 ] {741228af-8b7b-4616-94f8-a70b2cc17237} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(String, UInt64))))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:10:23.680984 [ 29580 ] {4dd3b9d7-47f9-47dc-a8a8-636ed498176b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:23.681553 [ 29580 ] {4dd3b9d7-47f9-47dc-a8a8-636ed498176b} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:23.759903 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:23.807392 [ 2803 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:23.812636 [ 29580 ] {2d956562-2f81-410d-8062-c6741e8ee6e4} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(Array(Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:23.813458 [ 29580 ] {2d956562-2f81-410d-8062-c6741e8ee6e4} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3821b 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.057096 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.143177 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.220809 [ 2717 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:24.234716 [ 2770 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:24.282212 [ 29580 ] {dc3d370e-d169-49b4-9b8d-36ed375e39ae} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.283013 [ 29580 ] {dc3d370e-d169-49b4-9b8d-36ed375e39ae} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.593145 [ 29580 ] {adfeafdc-864e-4d6f-bc10-e402cf279b89} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, Map(String, Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.594118 [ 29580 ] {adfeafdc-864e-4d6f-bc10-e402cf279b89} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 9. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.760806 [ 2953 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:24.808133 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:24.809203 [ 29580 ] {38746d56-07e1-4e28-b21f-830c67a3da88} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.809878 [ 29580 ] {38746d56-07e1-4e28-b21f-830c67a3da88} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac77c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:24.997888 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:25.027078 [ 4083 ] {ba546f8d-4b98-4cff-a013-25454b58d3de} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/777/7779edca-b815-4b88-adca-6384948e7a52/-3_91_117_1/ in table test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52) located on disk default of type local, from mark 0 with max_rows_to_read = 17880): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39438) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:10:25.035886 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:25.081587 [ 4083 ] {ba546f8d-4b98-4cff-a013-25454b58d3de} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/777/7779edca-b815-4b88-adca-6384948e7a52/-3_91_117_1/ in table test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52) located on disk default of type local, from mark 0 with max_rows_to_read = 17880): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:10:25.134119 [ 29580 ] {1c1a9dbd-da26-46c3-9f39-291aee81b5e2} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, Variant(String, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:25.135011 [ 29580 ] {1c1a9dbd-da26-46c3-9f39-291aee81b5e2} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826ef82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:25.221837 [ 2823 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:25.235609 [ 2806 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:25.631129 [ 29580 ] {33322228-2c09-49bb-86cb-d67238685b90} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('42', 'Variant(String, LowCardinality(UInt64))') SETTINGS allow_experimental_variant_type = 1. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select 42::Variant(String, LowCardinality(UInt64)) settings allow_experimental_variant_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:25.631911 [ 29580 ] {33322228-2c09-49bb-86cb-d67238685b90} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('42', 'Variant(String, LowCardinality(UInt64))') SETTINGS allow_experimental_variant_type = 1. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:25.819452 [ 3118 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:25.819468 [ 3175 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:25.873442 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:25.894824 [ 29580 ] {95aeb639-df8c-458a-b948-a1925b84447a} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 11. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:10:25.896864 [ 29580 ] {95aeb639-df8c-458a-b948-a1925b84447a} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 11. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:10:25.917536 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.065305 [ 29580 ] {0f36f16c-aeec-402e-92a0-cab4a076f7eb} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Variant(LowCardinality(UInt64), 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.065954 [ 29580 ] {0f36f16c-aeec-402e-92a0-cab4a076f7eb} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.223052 [ 3068 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.236533 [ 3065 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.281983 [ 29580 ] {d016a132-89d7-4007-935a-ded66177ae37} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 11. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 13. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.282763 [ 29580 ] {d016a132-89d7-4007-935a-ded66177ae37} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f0c9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 11. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 13. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.456571 [ 4083 ] {75c218e2-383b-46fe-acbe-4205277027ee} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39500) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.457997 [ 4083 ] {75c218e2-383b-46fe-acbe-4205277027ee} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.458274 [ 6456 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.459511 [ 3038 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.459736 [ 2728 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.459801 [ 3104 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.459968 [ 2728 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.460398 [ 3107 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.460951 [ 3109 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.461518 [ 2868 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.461869 [ 2778 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.462231 [ 3155 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.463094 [ 3088 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.463511 [ 3103 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.463879 [ 3119 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.464104 [ 2917 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.464548 [ 2955 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.465167 [ 2775 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.465598 [ 2811 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.465965 [ 2720 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.466632 [ 2882 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.468626 [ 3113 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.469094 [ 2754 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.469454 [ 3156 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.470249 [ 2990 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.470912 [ 2843 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:26.472091 [ 2852 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.472224 [ 2859 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.472270 [ 3194 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.472245 [ 3128 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.472244 [ 2931 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.472745 [ 3178 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.556187 [ 29580 ] {c3db9999-0bb0-473c-8504-a4c8f4e06943} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('42', 'Variant(UInt64, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select '42'::Variant(UInt64, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:26.564641 [ 29580 ] {c3db9999-0bb0-473c-8504-a4c8f4e06943} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('42', 'Variant(UInt64, FixedString(1000000))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 2025.06.12 19:10:26.706877 [ 29580 ] {a3c6fcfd-d1c8-4f78-a508-4153bbbe0559} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))))'). (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', '42')])::Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 11. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:10:26.741501 [ 29580 ] {a3c6fcfd-d1c8-4f78-a508-4153bbbe0559} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))))'). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./build_docker/./src/DataTypes/DataTypeMap.cpp:139: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87224 8. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 11. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761a4b4 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008714e8b 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008714b31 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871564b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174baa34 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:10:26.773972 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.778853 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.820627 [ 2901 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.820669 [ 3007 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:26.839416 [ 29580 ] {24d0b8e2-b878-46bf-b9d8-294d8880da41} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Variant(UInt64, FixedString(1000000))) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.840230 [ 29580 ] {24d0b8e2-b878-46bf-b9d8-294d8880da41} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x0000000016eb149c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.848697 [ 29580 ] {4918a8d0-df44-4346-bc5d-344c840bc775} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60056) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, FixedString(1000000))))) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:26.849418 [ 29580 ] {4918a8d0-df44-4346-bc5d-344c840bc775} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000182702a6 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000001826f063 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018270241 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x0000000016e87204 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:76: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x0000000016e3823a 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000016eac79c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001826df9c 10. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x0000000017c3e5cc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:894: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c3bd3d 12. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c426d9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 23. __tsan_thread_start_func @ 0x000000000758af2f 24. ? @ 0x00007f4e69e13ac3 25. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:27.223976 [ 2883 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:27.237443 [ 2938 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:27.611466 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:27.621221 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:27.821489 [ 2823 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:27.821579 [ 2891 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:27.905108 [ 4083 ] {7b0cc71b-b526-4108-921b-8e33e8aff263} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39546) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:27.906157 [ 4083 ] {7b0cc71b-b526-4108-921b-8e33e8aff263} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:28.224944 [ 2690 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:28.238190 [ 3098 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:28.480193 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:28.543522 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:28.822283 [ 2700 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:28.822716 [ 3121 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:29.225738 [ 3060 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:29.238989 [ 2967 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:29.328265 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:29.353007 [ 29516 ] {de3202b4-4309-4200-810f-d1911d1f3f98} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39588) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:29.354109 [ 29516 ] {de3202b4-4309-4200-810f-d1911d1f3f98} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:29.366762 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:29.822952 [ 2990 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:29.823422 [ 2811 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:30.177205 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:30.198088 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:30.226386 [ 2981 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:30.264750 [ 3184 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:30.823538 [ 29516 ] {332c4604-1d35-4a28-b144-4dc01fa5aedb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39652) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:30.823950 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:30.824115 [ 2721 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:30.824542 [ 29516 ] {332c4604-1d35-4a28-b144-4dc01fa5aedb} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:31.029961 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:31.040408 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:31.227301 [ 2751 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:31.265566 [ 3115 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:31.824754 [ 3085 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:31.824806 [ 2944 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:31.878308 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:31.908320 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:32.228032 [ 3070 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:32.266293 [ 2977 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:32.349011 [ 29516 ] {147e7fbc-86a7-42a4-8590-c1ba47de9c8c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42056) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:32.350080 [ 29516 ] {147e7fbc-86a7-42a4-8590-c1ba47de9c8c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:32.545886 [ 3275 ] {54d0031a-0218-4143-b8ed-fcfbf13eabbc::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:32.705627 [ 3275 ] {54d0031a-0218-4143-b8ed-fcfbf13eabbc::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000e1fa74c 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e1fa5e7 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e1f9a94 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007632b7e 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000018c6fb09 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000018c6f75f 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x00000000190c8e36 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad8d741 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2e1c66 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a2f6ede 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a2f70e1 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019c954b6 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019cc0cfd 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cbb194 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019c9935b (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:32.717041 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:32.760119 [ 29577 ] {1321cbe6-24cb-4867-baf2-b16ae1b92c42} executeQuery: Code: 341. DB::Exception: Mutation mutation_3.txt was killed. (UNFINISHED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42060) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: ALTER TABLE t1 UPDATE i = sleepEachRow(3) IN PARTITION id '1' WHERE p == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019b98097 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e4a360 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b7c2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:32.761411 [ 29577 ] {1321cbe6-24cb-4867-baf2-b16ae1b92c42} TCPHandler: Code: 341. DB::Exception: Mutation mutation_3.txt was killed. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019b98097 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e4a360 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e4b7c2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c20c17 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:32.825633 [ 2910 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:32.825954 [ 2718 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:32.830882 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:33.228852 [ 3001 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:33.267429 [ 3065 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:33.553587 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:33.658098 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:33.826901 [ 2728 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:33.826965 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:33.879310 [ 29516 ] {95a21bb6-dfa1-4a49-acc6-081fd2fd3a75} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42112) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:33.880470 [ 29516 ] {95a21bb6-dfa1-4a49-acc6-081fd2fd3a75} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:34.229534 [ 2743 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:34.268105 [ 3182 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:34.385523 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:34.485372 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:34.827769 [ 3055 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:34.827780 [ 2887 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:35.210379 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:35.230194 [ 3115 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:35.268923 [ 3092 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:35.318005 [ 29516 ] {bb515b7e-ccd7-4976-b414-ae341e505967} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42150) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:35.319354 [ 29516 ] {bb515b7e-ccd7-4976-b414-ae341e505967} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:35.322337 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:35.829411 [ 2864 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:35.829417 [ 2835 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:36.043000 [ 29516 ] {70b5d328-848b-49e4-a49d-c093327f569a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42162) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: SELECT is_done as is_running FROM system.mutations WHERE database==currentDatabase() AND table=='t1'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:36.043504 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:36.045427 [ 29516 ] {70b5d328-848b-49e4-a49d-c093327f569a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:36.210903 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:36.231299 [ 2936 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:36.269830 [ 2784 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:36.830260 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:36.830339 [ 3098 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:36.874878 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:36.889521 [ 29516 ] {5984456c-8724-4f49-9d1a-e1e09d1db2c6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42182) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:36.890821 [ 29516 ] {5984456c-8724-4f49-9d1a-e1e09d1db2c6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:37.061740 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:37.232336 [ 3076 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.271486 [ 3121 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.715098 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:37.830987 [ 2757 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.831152 [ 2684 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.879843 [ 3060 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.879947 [ 3003 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.880200 [ 3178 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.880353 [ 2728 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.881008 [ 3073 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.881547 [ 2965 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.881762 [ 3009 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.882101 [ 2844 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.882617 [ 3128 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.882442 [ 2850 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.882952 [ 2742 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.883919 [ 3173 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.884238 [ 2866 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.884710 [ 2852 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.885077 [ 2961 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.885621 [ 2781 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.886107 [ 3142 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.886328 [ 2707 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.887963 [ 2691 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.888073 [ 2966 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.888442 [ 3047 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.888705 [ 2762 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:37.889786 [ 2859 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.889833 [ 2962 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.889858 [ 2967 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.889867 [ 3194 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.889883 [ 2714 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.889941 [ 3025 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.891785 [ 2962 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:37.900800 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:38.032232 [ 2818 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:38.233031 [ 2799 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:38.272341 [ 2900 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:38.555123 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:38.750257 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:38.831879 [ 2963 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:38.831895 [ 3006 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:39.233763 [ 2784 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:39.273226 [ 3135 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:39.378556 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:39.665030 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:39.750787 [ 29516 ] {e367c3ad-ed0b-41e3-8e37-c19597dcafd7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column c): (while reading from part /var/lib/clickhouse/store/764/764b68fe-a6f6-4b5d-ae50-c17628a53bc9/-6_70_121_1/ in table test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9) located on disk default of type local, from mark 1 with max_rows_to_read = 17880): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42248) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe9dcb 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:10:39.832695 [ 3050 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:39.832707 [ 2694 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:39.886378 [ 29516 ] {e367c3ad-ed0b-41e3-8e37-c19597dcafd7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column c): (while reading from part /var/lib/clickhouse/store/764/764b68fe-a6f6-4b5d-ae50-c17628a53bc9/-6_70_121_1/ in table test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9) located on disk default of type local, from mark 1 with max_rows_to_read = 17880): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe9dcb 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:10:40.208976 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:40.234467 [ 2779 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:40.274074 [ 3146 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:40.498069 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:40.763411 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {14a4948f-ad6d-4f55-847a-9babfee874f5::202506_1_180_36}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:40.833502 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:40.833540 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:41.044752 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:41.235433 [ 3195 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:41.319617 [ 3190 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:41.339016 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:41.351938 [ 30753 ] {c9737030-6741-452e-becf-2c6ce5413487} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42332) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:41.352862 [ 30753 ] {c9737030-6741-452e-becf-2c6ce5413487} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:41.834250 [ 2704 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:41.834254 [ 2853 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:41.885625 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:42.236278 [ 3071 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:42.257883 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:42.320443 [ 2812 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:42.709904 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:42.834956 [ 2971 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:42.835346 [ 3058 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:43.166737 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:43.237013 [ 2966 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:43.321090 [ 3156 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:43.431546 [ 31269 ] {e2cffb0e-ef29-4730-8732-23089f252a4a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58324) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:43.432655 [ 31269 ] {e2cffb0e-ef29-4730-8732-23089f252a4a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:43.583068 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:43.835612 [ 2979 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:43.836113 [ 3017 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:44.003917 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:44.237751 [ 3102 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:44.321860 [ 3005 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:44.407932 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:44.837133 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:44.837273 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:44.837275 [ 2748 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:44.899103 [ 31269 ] {2a81fb53-ff5a-4df7-bc0a-1ad4b5168b09} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58408) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:44.900519 [ 31269 ] {2a81fb53-ff5a-4df7-bc0a-1ad4b5168b09} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:45.238546 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:45.238591 [ 3146 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:45.322888 [ 3160 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:45.738634 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:45.838392 [ 2771 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:45.838460 [ 3167 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:46.070638 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:46.239618 [ 3024 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:46.323838 [ 2841 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:46.346829 [ 30753 ] {b6a23b0e-d160-4c2f-8e9e-47523a5fc3ca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58462) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:46.348076 [ 30753 ] {b6a23b0e-d160-4c2f-8e9e-47523a5fc3ca} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:46.563322 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:46.839485 [ 2985 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:46.839561 [ 3124 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:46.899310 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:47.240362 [ 3082 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:47.324714 [ 3129 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:47.397541 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:47.721985 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:47.840496 [ 2931 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:47.840567 [ 2774 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:48.146719 [ 31269 ] {33532b92-35c1-4e55-bd0e-3b23a8daa3b3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58542) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:48.148153 [ 31269 ] {33532b92-35c1-4e55-bd0e-3b23a8daa3b3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:48.223940 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:48.241144 [ 2939 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:48.325484 [ 3196 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:48.547046 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:48.841436 [ 2850 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:48.841497 [ 2926 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:49.048284 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:49.241945 [ 3023 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:49.326559 [ 3028 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:49.392495 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:49.653157 [ 31269 ] {a79c20c2-76fa-4949-9a7a-f9038f3c4d3a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58604) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:49.654899 [ 31269 ] {a79c20c2-76fa-4949-9a7a-f9038f3c4d3a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:49.842224 [ 2748 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:49.842277 [ 3162 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:49.884826 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:50.242881 [ 2904 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:50.256509 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:50.327395 [ 3050 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:50.782952 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:50.842987 [ 2718 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:50.843435 [ 2700 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:51.086848 [ 31255 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:51.098142 [ 31269 ] {eb9bf23a-eb88-4699-b595-e43fcb735287} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58646) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:51.132836 [ 31269 ] {eb9bf23a-eb88-4699-b595-e43fcb735287} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:51.243642 [ 2826 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:51.328062 [ 2855 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:51.603913 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:51.843702 [ 3138 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:51.844157 [ 3142 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:51.988925 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:52.244444 [ 3113 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:52.328739 [ 2786 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:52.466702 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:52.581088 [ 31269 ] {374e31cf-b813-4117-829a-00ca1d6a4237} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43212) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:52.582309 [ 31269 ] {374e31cf-b813-4117-829a-00ca1d6a4237} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:52.818604 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:52.844449 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:52.844832 [ 2975 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.245211 [ 2702 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.312599 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:53.329450 [ 2747 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.635351 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:53.758361 [ 17151 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.759223 [ 2924 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.759576 [ 2763 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.759657 [ 2996 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.759730 [ 3179 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.759862 [ 3000 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.760190 [ 3171 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.760505 [ 2935 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.760700 [ 3034 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.760791 [ 2904 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.760998 [ 3077 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.761517 [ 3126 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.761647 [ 2891 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.761765 [ 2683 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.762002 [ 3177 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.762306 [ 3050 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.762806 [ 2790 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.762839 [ 3021 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.763095 [ 2908 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.763350 [ 2809 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.763590 [ 2694 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.763888 [ 3062 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.764144 [ 2982 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.765312 [ 2921 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:53.766090 [ 3051 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.766422 [ 3140 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.766419 [ 2886 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.766455 [ 2938 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.766562 [ 2814 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.766541 [ 2731 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.767049 [ 2733 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.767396 [ 2779 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.845356 [ 2807 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:53.845556 [ 3117 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.025861 [ 31230 ] {d785d04b-b450-4cc9-a502-148aec4ea735} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43260) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:54.027290 [ 31230 ] {d785d04b-b450-4cc9-a502-148aec4ea735} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:54.184988 [ 2868 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.185059 [ 2743 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.185190 [ 3042 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.185224 [ 2957 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.187703 [ 2969 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.187768 [ 2740 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.187957 [ 2879 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.187983 [ 3168 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.188287 [ 2867 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.188471 [ 3128 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.188575 [ 2812 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.188948 [ 2773 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.189027 [ 2691 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.189288 [ 3038 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.189357 [ 2844 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.189474 [ 2990 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.189622 [ 2954 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.189912 [ 2961 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.190078 [ 3158 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.190260 [ 3094 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.190622 [ 2895 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.190454 [ 2843 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:10:54.191397 [ 2792 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.191468 [ 2888 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.191506 [ 3150 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.191579 [ 2874 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.191723 [ 3182 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.191732 [ 2950 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.191904 [ 3071 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.197740 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:54.245863 [ 2892 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.330291 [ 2919 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.455247 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:54.847038 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:54.851128 [ 2750 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:55.027442 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:55.247125 [ 2886 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:55.278091 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:55.331058 [ 2806 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:55.715199 [ 31269 ] {c39aac83-3b15-4e5f-a03e-caa29daca8fb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43326) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:55.716776 [ 31269 ] {c39aac83-3b15-4e5f-a03e-caa29daca8fb} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:55.848074 [ 3057 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:55.851878 [ 3179 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:55.858122 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:56.136892 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:56.248053 [ 3022 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:56.331888 [ 3002 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:56.684661 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:56.849282 [ 3004 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:56.852570 [ 2905 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:56.972195 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:57.248856 [ 2935 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:57.332771 [ 2859 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:57.516594 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:57.798699 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:57.850069 [ 3121 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:57.853327 [ 3108 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:58.055389 [ 31269 ] {88be14a0-5857-4db1-9aae-36cc5e00134a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43400) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:58.056398 [ 31269 ] {88be14a0-5857-4db1-9aae-36cc5e00134a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:58.249880 [ 3070 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:58.333524 [ 3079 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:58.351482 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:58.626931 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:58.851079 [ 2718 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:58.854175 [ 3068 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:59.201681 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:59.251158 [ 2897 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:59.334422 [ 2931 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:59.457495 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:59.597472 [ 31230 ] {db628bfd-2b37-4d1d-b25a-43c525605e80} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43488) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:59.598780 [ 31230 ] {db628bfd-2b37-4d1d-b25a-43c525605e80} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:10:59.851945 [ 3171 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:10:59.854940 [ 2967 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:00.034033 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:00.251950 [ 3103 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:00.296288 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:00.335346 [ 3116 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:00.852763 [ 2834 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:00.855724 [ 2838 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:00.868736 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:01.122241 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:01.175987 [ 31269 ] {9b713e79-fe4a-4d21-afda-3e94dfb96b36} 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.10057.altinitytest (altinity build)) (from [::1]:43540) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:01.176963 [ 31269 ] {9b713e79-fe4a-4d21-afda-3e94dfb96b36} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:01.252687 [ 3153 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:01.336155 [ 2877 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:01.698051 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:01.853646 [ 2818 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:01.856506 [ 2754 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:01.965302 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:02.253418 [ 2774 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:02.336890 [ 2744 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:02.521783 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:02.849581 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:02.854708 [ 2861 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:02.857344 [ 2842 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:03.169259 [ 31269 ] {9923bf83-f0c9-4ee8-b82b-be4a100a2ab2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39702) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:03.170261 [ 31269 ] {9923bf83-f0c9-4ee8-b82b-be4a100a2ab2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:03.254171 [ 3185 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:03.337736 [ 2874 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:03.352483 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:03.681281 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:03.856281 [ 3071 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:03.858118 [ 3113 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:04.188251 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:04.254908 [ 2858 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:04.338770 [ 2975 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:04.511430 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:04.623436 [ 31230 ] {2178a2f6-65de-4cc3-9efa-0b3012dfefc8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39766) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:04.624470 [ 31230 ] {2178a2f6-65de-4cc3-9efa-0b3012dfefc8} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:04.857000 [ 3145 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:04.858925 [ 2752 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:05.019564 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:05.255657 [ 3069 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:05.337425 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:05.339466 [ 2999 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:05.852531 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:05.858138 [ 2803 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:05.859879 [ 2783 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:06.066305 [ 31230 ] {de972abe-3b86-4349-9033-eb97d5563bc1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39824) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:06.127517 [ 31230 ] {de972abe-3b86-4349-9033-eb97d5563bc1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:06.162286 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:06.256358 [ 2933 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:06.340167 [ 3189 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:06.699611 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:06.859175 [ 3058 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:06.860724 [ 3094 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:06.991880 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:07.073453 [ 3029 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.073554 [ 3021 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.073552 [ 2695 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.073561 [ 2700 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.073876 [ 2800 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.073571 [ 3149 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.074116 [ 3090 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.074262 [ 2758 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.074615 [ 2970 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.075003 [ 3036 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.075241 [ 3021 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.075307 [ 3029 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.075436 [ 2700 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.075411 [ 3053 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.075771 [ 3149 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.076407 [ 2695 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.076557 [ 3029 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.076693 [ 3090 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.076965 [ 2872 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.077211 [ 3084 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.077476 [ 2919 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.078085 [ 3033 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.078038 [ 3165 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.078544 [ 3183 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.078548 [ 2839 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.078988 [ 2753 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.079384 [ 2969 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.079566 [ 2900 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.079938 [ 3156 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.080325 [ 2701 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.080790 [ 2777 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.080928 [ 2878 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.081321 [ 2966 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.081584 [ 2896 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.083188 [ 2683 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.084282 [ 2683 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.257094 [ 2963 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.341007 [ 3078 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.438054 [ 3274 ] {} 38b1b594-8cf2-483c-bb28-07c4a85bce95::0_94_125_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.438692 [ 3274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {38b1b594-8cf2-483c-bb28-07c4a85bce95::0_94_125_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.514358 [ 3272 ] {} 7779edca-b815-4b88-adca-6384948e7a52::0_94_125_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.528319 [ 5085 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.534808 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:07.545602 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7779edca-b815-4b88-adca-6384948e7a52::0_94_125_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.545817 [ 3082 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.546151 [ 3195 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.546271 [ 2860 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.546536 [ 2796 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.547708 [ 2978 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.547786 [ 2935 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.547942 [ 2859 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.548791 [ 2832 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.549076 [ 3099 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.549285 [ 2911 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.549316 [ 3034 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.549789 [ 3111 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.549793 [ 3091 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.550132 [ 2876 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.550174 [ 3129 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.551423 [ 2914 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.551579 [ 3121 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.551593 [ 2994 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.551676 [ 2725 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.551941 [ 3108 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.553034 [ 2802 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.553102 [ 2986 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:07.554392 [ 3151 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.554496 [ 2889 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.554553 [ 3065 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.554446 [ 3186 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.555204 [ 2885 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.555578 [ 2694 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.555985 [ 2741 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.556591 [ 3175 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.556720 [ 3124 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.557054 [ 3070 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.557147 [ 2819 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.557410 [ 3154 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.557443 [ 3079 ] {} test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.557453 [ 2696 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.557951 [ 2703 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.558044 [ 3061 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.558913 [ 2713 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.558914 [ 3134 ] {} test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.559629 [ 3081 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.559687 [ 3118 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.559753 [ 2997 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.559862 [ 3061 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.559854 [ 2718 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.560118 [ 3044 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.560186 [ 3019 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.664279 [ 30981 ] {2b073d37-aac6-42a1-b173-af6983829a61} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39890) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:07.665574 [ 30981 ] {2b073d37-aac6-42a1-b173-af6983829a61} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:07.844516 [ 3089 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b616ea0 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x000000001adc1b06 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5c06 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d44cd3 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 15. __tsan_thread_start_func @ 0x000000000758af2f 16. ? @ 0x00007f4e69e13ac3 17. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.846145 [ 3089 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.859944 [ 2967 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.861319 [ 3194 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:07.872412 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:08.041527 [ 3278 ] {} 764b68fe-a6f6-4b5d-ae50-c17628a53bc9::0_94_125_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:08.042157 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {764b68fe-a6f6-4b5d-ae50-c17628a53bc9::0_94_125_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001995818a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d35a34 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d34249 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 31. __tsan_thread_start_func @ 0x000000000758af2f (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:08.258704 [ 2705 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:08.341854 [ 2695 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:08.382052 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:08.742274 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:08.924611 [ 3133 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:08.924611 [ 2726 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:09.229555 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:09.260304 [ 3102 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:09.343215 [ 3115 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:09.570727 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:09.707855 [ 31230 ] {3d83153a-fa9f-48f3-b5d0-1986ce321d63} 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.10057.altinitytest (altinity build)) (from [::1]:39916) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:09.708957 [ 31230 ] {3d83153a-fa9f-48f3-b5d0-1986ce321d63} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:09.925936 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:09.925940 [ 3117 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:10.067662 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:10.261025 [ 2836 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:10.344024 [ 3023 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:10.422280 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:10.895031 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:10.927243 [ 3024 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:10.927247 [ 3076 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:11.196894 [ 31230 ] {300a0d09-df9f-4138-b73e-14c921af3081} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:39982) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:11.198022 [ 31230 ] {300a0d09-df9f-4138-b73e-14c921af3081} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:11.237784 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:11.261739 [ 2881 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:11.344804 [ 3177 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:11.714126 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:11.928307 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:11.928344 [ 2985 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:12.059305 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:12.262445 [ 3175 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:12.345600 [ 2819 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:12.536650 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:12.768407 [ 31230 ] {a22e17de-ac3d-4ab1-a91a-4f9bec31631a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34666) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:12.769481 [ 31230 ] {a22e17de-ac3d-4ab1-a91a-4f9bec31631a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:12.892177 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:12.929199 [ 2959 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:12.929300 [ 2815 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:13.263478 [ 3125 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:13.346632 [ 3194 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:13.369785 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:13.730558 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:13.930060 [ 2931 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:13.930075 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:14.202082 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:14.264276 [ 2826 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:14.347738 [ 3037 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:14.637591 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:14.812549 [ 31230 ] {3c0dba05-b769-4016-9058-58a9c9d95f8f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34706) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:14.815083 [ 31230 ] {3c0dba05-b769-4016-9058-58a9c9d95f8f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:14.931202 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:14.931305 [ 3034 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:15.051032 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:15.265726 [ 3062 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:15.348872 [ 3123 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:15.460184 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:15.899699 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:15.932100 [ 3088 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:15.932297 [ 2790 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:16.266831 [ 2918 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:16.281441 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:16.350025 [ 3040 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:16.514817 [ 31230 ] {1223a1bb-f34f-48e2-8483-bd177e75e6a0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34778) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:16.515875 [ 31230 ] {1223a1bb-f34f-48e2-8483-bd177e75e6a0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:16.732005 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:16.925975 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_141_146_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:16.932913 [ 3071 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:16.933183 [ 2880 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:17.106308 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:17.267661 [ 3060 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:17.351144 [ 2792 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:17.573397 [ 31230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:17.933703 [ 2816 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:17.933886 [ 2773 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:17.995893 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:18.268508 [ 2786 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:18.351917 [ 2803 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:18.397435 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:18.616692 [ 31230 ] {84b11a5f-8a38-455c-827d-1bb4c6de0028} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34830) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:18.617662 [ 31230 ] {84b11a5f-8a38-455c-827d-1bb4c6de0028} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:18.850577 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:18.995410 [ 3092 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:18.995405 [ 2926 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.224419 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:19.269324 [ 3056 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.352734 [ 2755 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.399269 [ 3268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3655178d-96ea-42c6-867f-61b9ceac796e::202506_1_129_28}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.559089 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_177_36}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.690267 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:19.781929 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_141_146_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.992116 [ 3148 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.992161 [ 2915 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.992292 [ 2973 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.992238 [ 2904 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.992180 [ 2930 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.993021 [ 3058 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.993124 [ 3078 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.993319 [ 2930 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.993791 [ 2964 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.994104 [ 3017 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.994296 [ 3148 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.994625 [ 2864 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.994792 [ 2973 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.995242 [ 2837 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.995667 [ 2963 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.997117 [ 2963 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.997710 [ 3078 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.997889 [ 2904 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.997861 [ 2970 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.998015 [ 3078 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.998178 [ 3007 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.998426 [ 3006 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.998497 [ 3156 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.998686 [ 2868 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:19.998946 [ 3028 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.999014 [ 3107 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.999547 [ 2772 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.999796 [ 2904 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.000055 [ 2904 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:19.999969 [ 2901 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.000201 [ 3120 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.000648 [ 2770 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.001305 [ 2899 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.001736 [ 2813 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.001911 [ 3165 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.001917 [ 3170 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.002346 [ 2945 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.002781 [ 2942 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:20.004276 [ 3013 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.004433 [ 2727 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.004789 [ 3000 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.004849 [ 2777 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.004973 [ 2896 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.006154 [ 3000 ] {} test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000001ae57c39 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001ade2689 6. ./contrib/llvm-project/libcxx/include/future:1062: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add0c6e 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001add5b78 8. ./contrib/llvm-project/libcxx/include/vector:1252: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x000000001929c4ae 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001929c178 10. ./src/Common/ZooKeeper/ZooKeeper.h:0: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001943a50a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000194378f2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x000000001943678a 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d409b1 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.010216 [ 3000 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.070319 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:20.107260 [ 3271 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_177_36}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.136996 [ 30981 ] {b1dbf079-26c7-4691-a620-25ef19332d50} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34896) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:20.138251 [ 30981 ] {b1dbf079-26c7-4691-a620-25ef19332d50} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:20.270591 [ 3100 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.353611 [ 3001 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.520851 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:20.900954 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:20.999327 [ 2754 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:20.999848 [ 2802 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:21.271631 [ 3138 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:21.354460 [ 2829 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:21.364625 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:21.735133 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:21.875214 [ 30981 ] {71932d2d-5b7c-40b3-abe5-94bd57ea54a4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34968) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:21.878946 [ 30981 ] {71932d2d-5b7c-40b3-abe5-94bd57ea54a4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:22.000732 [ 3099 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:22.001010 [ 3193 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:22.272398 [ 3195 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:22.327167 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:22.355324 [ 2786 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:22.582950 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:23.001674 [ 3072 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:23.001851 [ 2849 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:23.150660 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:23.273124 [ 3105 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:23.356613 [ 3114 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:23.496166 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:23.681216 [ 30981 ] {d215692e-b75d-42b1-b53d-0a04ad0f78b0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35970) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:23.682176 [ 30981 ] {d215692e-b75d-42b1-b53d-0a04ad0f78b0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:23.982069 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:24.002763 [ 2881 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:24.002874 [ 3023 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:24.274168 [ 3172 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:24.317446 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:24.357913 [ 2932 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:24.815312 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:25.003678 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:25.003905 [ 2775 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:25.211522 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:25.275096 [ 2794 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:25.339917 [ 29580 ] {0ccca22c-fc4d-4711-a78c-a452e0727244} 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.10057.altinitytest (altinity build)) (from [::1]:36040) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:25.341127 [ 29580 ] {0ccca22c-fc4d-4711-a78c-a452e0727244} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:25.436972 [ 3184 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:25.640601 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:26.004420 [ 2691 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.004676 [ 3060 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.088235 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:26.174122 [ 17136 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.175002 [ 2975 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.175087 [ 2722 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.175373 [ 2893 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.175514 [ 2989 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.175847 [ 3048 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.176159 [ 2895 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.176456 [ 2917 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.176571 [ 3099 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.176808 [ 3193 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.177185 [ 2925 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.177530 [ 2734 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.177944 [ 2871 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.178180 [ 2882 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.178736 [ 2984 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.178769 [ 3131 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.179242 [ 2911 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.179465 [ 2697 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.179594 [ 2928 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.180100 [ 3082 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.180273 [ 2751 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.180733 [ 2768 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.180971 [ 3139 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:26.182136 [ 3122 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.182178 [ 3108 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.182203 [ 2851 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.182154 [ 2740 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.182510 [ 2797 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.182510 [ 2875 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.182533 [ 3164 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.182883 [ 3069 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.184093 [ 3122 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.182546 [ 3178 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.275842 [ 2803 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.437863 [ 2708 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:26.469932 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:26.924219 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:27.005339 [ 3022 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:27.005535 [ 2951 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:27.225553 [ 31184 ] {aa99bbfc-701f-4ea6-a0a3-71f365e9ea90} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36086) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:27.226627 [ 31184 ] {aa99bbfc-701f-4ea6-a0a3-71f365e9ea90} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:27.276538 [ 3004 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:27.305267 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:27.518182 [ 3053 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:27.802386 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:28.006345 [ 2802 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:28.006407 [ 2865 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:28.163462 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:28.277252 [ 2818 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:28.518952 [ 2981 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:28.649800 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:28.991252 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:29.009071 [ 3049 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.009109 [ 2797 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.277886 [ 3195 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.519998 [ 2973 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.524052 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:29.784753 [ 2810 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.784923 [ 2925 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.785041 [ 2839 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.785206 [ 3092 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.785551 [ 2791 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.785639 [ 2764 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.785831 [ 3104 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.786005 [ 3041 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.786127 [ 3052 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.786285 [ 3188 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.786467 [ 2915 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.786817 [ 2707 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.787007 [ 2835 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.787080 [ 2768 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.787273 [ 3000 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.787480 [ 2742 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.787582 [ 2737 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.787776 [ 2995 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.788021 [ 3120 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.788282 [ 2966 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.788569 [ 2750 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.788792 [ 2769 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:29.789540 [ 2747 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.789615 [ 2983 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.789678 [ 2990 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.789637 [ 2895 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.789783 [ 2787 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.789636 [ 2726 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.791028 [ 2990 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:29.816919 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:30.009881 [ 2813 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:30.009946 [ 2827 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:30.055146 [ 2697 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:30.311339 [ 2836 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:30.358139 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:30.521006 [ 2841 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:30.642452 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:30.787886 [ 31184 ] {922f1a4c-5577-4203-b9d6-8cdf16d6c4d5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/a99/a991c6ec-26b8-4e79-9287-7cf7432a7148/0_0_49_2/ in table test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148) located on disk default of type local, from mark 2 with max_rows_to_read = 26820): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:36168) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x00000000170275e9 19. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000017025def 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:11:31.059882 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:31.059924 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:31.200457 [ 31184 ] {922f1a4c-5577-4203-b9d6-8cdf16d6c4d5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/a99/a991c6ec-26b8-4e79-9287-7cf7432a7148/0_0_49_2/ in table test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148) located on disk default of type local, from mark 2 with max_rows_to_read = 26820): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x00000000170275e9 19. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000017025def 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50ab2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:11:31.204226 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:31.312278 [ 2735 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:31.502842 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:31.522005 [ 3088 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:32.040257 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:32.060668 [ 2863 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:32.060784 [ 2797 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:32.313223 [ 2845 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:32.343385 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:32.523004 [ 3020 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:32.768677 [ 29580 ] {7d1185c5-63dc-4224-b12b-cfd5a79c8c5f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59976) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:32.769876 [ 29580 ] {7d1185c5-63dc-4224-b12b-cfd5a79c8c5f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:32.904640 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:33.061542 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:33.061709 [ 3041 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:33.170304 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:33.313991 [ 2717 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:33.523853 [ 2899 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:33.768681 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:34.037138 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:34.062340 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:34.062403 [ 3022 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:34.255872 [ 31184 ] {57ef5585-555c-4d92-9c40-c9ee86bca849} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60032) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:34.257548 [ 31184 ] {57ef5585-555c-4d92-9c40-c9ee86bca849} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:34.314963 [ 3039 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:34.525665 [ 2932 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:34.674886 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:34.878037 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:35.063252 [ 2716 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:35.063270 [ 3091 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:35.315754 [ 3123 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:35.526452 [ 2918 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:35.558581 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:35.714059 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:35.723011 [ 31184 ] {183cf764-4a65-4b29-8ac6-4be64c0fa5b8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60068) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:35.724348 [ 31184 ] {183cf764-4a65-4b29-8ac6-4be64c0fa5b8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:36.064181 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:36.064262 [ 2738 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:36.316539 [ 3016 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:36.432642 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:36.527694 [ 3032 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:36.543156 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:37.065121 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:37.065140 [ 2702 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:37.271259 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:37.317277 [ 3104 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:37.377658 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:37.529213 [ 3176 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:37.578012 [ 31184 ] {6ef8fc10-dee9-47e6-a669-84490f32ed7e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60128) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:37.579296 [ 31184 ] {6ef8fc10-dee9-47e6-a669-84490f32ed7e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:38.065856 [ 2956 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:38.066225 [ 3162 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:38.117900 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:38.208670 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:38.318182 [ 2871 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:38.529925 [ 2934 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:38.944432 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:39.033843 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:39.066739 [ 2959 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:39.067203 [ 2997 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:39.319109 [ 3077 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:39.469782 [ 4083 ] {afa2a4c3-dbed-4710-aa90-8f5ec74a2b12} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60198) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:39.470829 [ 4083 ] {afa2a4c3-dbed-4710-aa90-8f5ec74a2b12} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:39.530876 [ 2960 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:39.770850 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:39.859926 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:40.067930 [ 3173 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:40.068156 [ 2876 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:40.320141 [ 2762 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:40.531614 [ 2766 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:40.601440 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:40.699888 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:41.069999 [ 2851 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:41.070208 [ 3020 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:41.321032 [ 3032 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:41.415959 [ 31184 ] {3d1a7ab4-213a-4556-a0dc-a8f43a51ccfd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60242) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:41.417804 [ 31184 ] {3d1a7ab4-213a-4556-a0dc-a8f43a51ccfd} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:41.453590 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:41.531083 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:41.532613 [ 3189 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:42.071493 [ 2707 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:42.074274 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:42.321958 [ 2867 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:42.327945 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:42.479141 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:42.533420 [ 2729 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:42.881999 [ 31184 ] {8f0da433-7294-4b94-8e94-1de94789da86} 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.10057.altinitytest (altinity build)) (from [::1]:52968) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:42.883325 [ 31184 ] {8f0da433-7294-4b94-8e94-1de94789da86} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:43.072515 [ 2806 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.075241 [ 2785 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.135399 [ 3172 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.135631 [ 3039 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.136021 [ 2769 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.136142 [ 2791 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.136544 [ 3052 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.137247 [ 2809 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.137540 [ 2869 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.138035 [ 2948 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.138540 [ 2910 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.139224 [ 2886 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.140011 [ 2687 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.140342 [ 3086 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.141137 [ 2770 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.141398 [ 2920 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.142165 [ 3147 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.142615 [ 2778 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.143012 [ 2689 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.143293 [ 2779 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.143664 [ 2782 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.143993 [ 2881 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.144248 [ 3023 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.144940 [ 2730 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.145291 [ 3177 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:11:43.146628 [ 2733 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.146815 [ 2854 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.146846 [ 3098 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.147025 [ 2900 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.147059 [ 2972 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.147330 [ 3015 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.148136 [ 3100 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.149080 [ 3058 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.171209 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:43.339143 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:43.375437 [ 2775 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.534416 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:43.534853 [ 2810 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:44.014886 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:44.073416 [ 2937 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:44.076156 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:44.171853 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:44.376173 [ 2963 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:44.535390 [ 2927 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:44.851938 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:45.001825 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:45.074256 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:45.077005 [ 2726 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:45.377453 [ 3007 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:45.536443 [ 2938 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:45.705159 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:45.825191 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:46.031613 [ 31184 ] {f748d3fc-3d5f-422a-8fc0-b7a2a4935056} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/8_0_61_1/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 0 with max_rows_to_read = 17880): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53030) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:11:46.074891 [ 2708 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:46.077890 [ 3140 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:46.086165 [ 31184 ] {f748d3fc-3d5f-422a-8fc0-b7a2a4935056} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/8_0_61_1/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 0 with max_rows_to_read = 17880): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:11:46.378146 [ 2801 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:46.537431 [ 3010 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:46.558237 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:46.654684 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:47.075599 [ 2775 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:47.078656 [ 3187 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:47.378997 [ 2815 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:47.379852 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:47.473789 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:47.538268 [ 2897 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:48.076379 [ 3121 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:48.079387 [ 3103 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:48.189507 [ 31184 ] {f7eac7d5-b150-44c5-b34f-47322c0e0b03} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53140) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:48.190959 [ 31184 ] {f7eac7d5-b150-44c5-b34f-47322c0e0b03} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:48.237052 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:48.297142 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:48.379652 [ 2857 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:48.539289 [ 2797 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:49.068508 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:49.077043 [ 2816 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:49.079997 [ 3164 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:49.125771 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:49.406569 [ 3041 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:49.542229 [ 2839 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:49.877363 [ 31184 ] {bf4fa742-1e9a-4fe5-9bb5-7751691d855b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53190) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:49.879150 [ 31184 ] {bf4fa742-1e9a-4fe5-9bb5-7751691d855b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:49.907228 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:49.954234 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:50.077741 [ 2871 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:50.080578 [ 2745 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:50.407965 [ 2769 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:50.603724 [ 2742 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:50.754404 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:50.778605 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:51.078618 [ 3039 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:51.081227 [ 2770 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:51.408798 [ 3053 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:51.591576 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:51.604517 [ 2967 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:51.618784 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:51.984551 [ 29516 ] {77fe3006-4dd9-4d65-8361-22851eefaf4d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53272) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a974a86 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:52.027616 [ 29516 ] {77fe3006-4dd9-4d65-8361-22851eefaf4d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c05d83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a974a86 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9aad52 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a954b40 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e33b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 28. __tsan_thread_start_func @ 0x000000000758af2f 29. ? @ 0x00007f4e69e13ac3 30. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:52.080006 [ 2877 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:52.082209 [ 2684 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:52.409669 [ 2992 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:52.439618 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:52.444804 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:52.605271 [ 2978 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:53.081100 [ 3157 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:53.083038 [ 2783 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:53.279584 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:53.281506 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:53.410608 [ 2755 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:53.467078 [ 29516 ] {b1e4c4b7-1b32-4f1c-a7e5-c24e9591d174} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45510) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:53.468200 [ 29516 ] {b1e4c4b7-1b32-4f1c-a7e5-c24e9591d174} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:53.606130 [ 3082 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:54.081926 [ 3188 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:54.083728 [ 2708 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:54.114386 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:54.115584 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:54.411532 [ 2964 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:54.606914 [ 2919 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:54.946140 [ 29516 ] {9b0b7517-0867-434f-83b0-1de0471f62ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45546) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:54.948585 [ 29516 ] {9b0b7517-0867-434f-83b0-1de0471f62ad} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:54.950000 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:54.976855 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:55.082799 [ 3163 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:55.084414 [ 2772 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:55.412609 [ 2696 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:55.607783 [ 2865 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:55.775300 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:55.846451 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:56.083762 [ 2931 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:56.085192 [ 3138 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:56.413830 [ 2924 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:56.626955 [ 3052 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:56.681652 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:56.775846 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:57.084848 [ 2691 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:57.086262 [ 2689 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:57.189459 [ 29516 ] {856e50dd-9f2c-4cb5-b286-37dcf8396f5e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45606) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:57.191305 [ 29516 ] {856e50dd-9f2c-4cb5-b286-37dcf8396f5e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:57.414911 [ 2986 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:57.506432 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:57.601132 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:57.628310 [ 2961 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:58.085736 [ 2916 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:58.087020 [ 2866 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:58.344756 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:58.415726 [ 2743 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:58.433078 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:58.629320 [ 2729 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:58.642104 [ 29516 ] {ff30cec2-9c2e-477c-9a39-9cea70be1d3b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45680) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:58.643241 [ 29516 ] {ff30cec2-9c2e-477c-9a39-9cea70be1d3b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:59.087076 [ 2942 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:59.087818 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:59.173881 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:59.268450 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:11:59.416546 [ 3022 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:11:59.630156 [ 3156 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:00.017610 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:00.088158 [ 3089 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:00.088682 [ 3107 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:00.214730 [ 29516 ] {ff4a811e-af59-4058-b708-3852068748e6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45702) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:00.215717 [ 29516 ] {ff4a811e-af59-4058-b708-3852068748e6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:00.417260 [ 3194 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:00.530227 [ 2892 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160df283 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001769e9e7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000001769f17c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176aa3a2 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:00.631534 [ 2767 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:00.891702 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:01.088951 [ 3046 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:01.089474 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:01.418097 [ 2967 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:01.632492 [ 2790 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:01.673327 [ 29516 ] {61c36af1-e532-4bd9-b487-08876a9c07d5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45748) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:01.675123 [ 29516 ] {61c36af1-e532-4bd9-b487-08876a9c07d5} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:01.735907 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:02.089774 [ 2851 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:02.090152 [ 3016 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:02.418983 [ 3093 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:02.512031 [ 29516 ] {58d87e07-98f1-4269-9515-d0f4348e327b} executeQuery: Code: 46. DB::Exception: Function with name 'plu' does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41880) (comment: 02477_analyzer_function_hints.sh) (in query: SELECT plu(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bddd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:02.513229 [ 29516 ] {58d87e07-98f1-4269-9515-d0f4348e327b} TCPHandler: Code: 46. DB::Exception: Function with name 'plu' does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bddd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:02.577159 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:02.633300 [ 2870 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:02.924889 [ 29516 ] {ff6385c3-b602-44dd-823f-b0aae25ea0e8} executeQuery: Code: 46. DB::Exception: Function with name 'uniqExac' does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41912) (comment: 02477_analyzer_function_hints.sh) (in query: SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bddd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:02.926094 [ 29516 ] {ff6385c3-b602-44dd-823f-b0aae25ea0e8} TCPHandler: Code: 46. DB::Exception: Function with name 'uniqExac' does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bddd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:03.090717 [ 2904 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:03.090997 [ 2911 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:03.136197 [ 29516 ] {18a2d5c9-9666-4b97-bba2-ea05058b0b85} 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.10057.altinitytest (altinity build)) (from [::1]:41922) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:03.137789 [ 29516 ] {18a2d5c9-9666-4b97-bba2-ea05058b0b85} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:03.419661 [ 2942 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:03.446902 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:03.633992 [ 2906 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:04.008718 [ 29516 ] {101bd9c3-5d5d-4014-a9f1-85c669eb66bd} executeQuery: Code: 46. DB::Exception: Function with name 'test_user_defined_function_test_3A' does not exist. In scope SELECT test_user_defined_function_test_3A(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_3']. (UNKNOWN_FUNCTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41954) (comment: 02477_analyzer_function_hints.sh) (in query: SELECT test_user_defined_function_test_3A(1) 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bddd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:04.009785 [ 29516 ] {101bd9c3-5d5d-4014-a9f1-85c669eb66bd} TCPHandler: Code: 46. DB::Exception: Function with name 'test_user_defined_function_test_3A' does not exist. In scope SELECT test_user_defined_function_test_3A(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_3']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bddd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:04.091454 [ 2865 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:04.091804 [ 3175 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:04.270979 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:04.420322 [ 3155 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:04.634836 [ 3177 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:04.756846 [ 30753 ] {a77fb431-3f79-4cf8-9385-f031cb706168} executeQuery: Code: 46. DB::Exception: Function with name 'lambda_functio' does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41996) (comment: 02477_analyzer_function_hints.sh) (in query: WITH (x -> x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bddd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:04.758084 [ 30753 ] {a77fb431-3f79-4cf8-9385-f031cb706168} TCPHandler: Code: 46. DB::Exception: Function with name 'lambda_functio' does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bddd3 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:05.092239 [ 2939 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:05.092721 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:05.112869 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:05.282742 [ 29516 ] {e35e037f-ae2a-4fb9-b095-4e1c363f2880} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41978) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:05.284187 [ 29516 ] {e35e037f-ae2a-4fb9-b095-4e1c363f2880} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:05.325463 [ 30753 ] {e335d3ec-255f-4623-9d2f-4eb6d8ebb075} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42016) (comment: 02477_analyzer_function_hints.sh) (in query: SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd31e 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:05.326713 [ 30753 ] {e335d3ec-255f-4623-9d2f-4eb6d8ebb075} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000101c280c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd31e 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 25. __tsan_thread_start_func @ 0x000000000758af2f 26. ? @ 0x00007f4e69e13ac3 27. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:05.421252 [ 3088 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:05.636871 [ 3121 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:05.946282 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:06.093306 [ 2831 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:06.093577 [ 3167 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:06.422222 [ 2783 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:06.456879 [ 29516 ] {2a081620-f320-4501-89cd-30463ab59eeb} executeQuery: Code: 131. DB::Exception: Too large string size (1095207661) in function repeat, maximum is: 1073741824: while executing 'FUNCTION repeat('0.0001048576'_String :: 1, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8))) :: 0) -> repeat('0.0001048576'_String, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8)))) String : 2'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42072) (comment: 01404_roundUpToPowerOfTwoOrZero_safety.sql) (in query: -- repeat() with this length and this number of rows will allocation huge enough region (MSB set), -- which will cause roundUpToPowerOfTwoOrZero() returns 0 for such allocation (before the fix), -- and later repeat() will try to use this memory and will got SIGSEGV. SELECT repeat('0.0001048576', number * (number * (number * 255))) FROM numbers(65535);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000008886ea6 4. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000000e0c8aef 5. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0c16da 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:06.457604 [ 29516 ] {2a081620-f320-4501-89cd-30463ab59eeb} TCPHandler: Code: 131. DB::Exception: Too large string size (1095207661) in function repeat, maximum is: 1073741824: while executing 'FUNCTION repeat('0.0001048576'_String :: 1, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8))) :: 0) -> repeat('0.0001048576'_String, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8)))) String : 2'. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000008886ea6 4. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000000e0c8aef 5. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0c16da 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076339bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871160b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176bf56a 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a694111 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe42357 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2cae85 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:06.637994 [ 3079 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:06.838202 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:07.013865 [ 30753 ] {4575cd97-5a71-4c77-b54c-be49e900eb3c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42082) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:07.015447 [ 30753 ] {4575cd97-5a71-4c77-b54c-be49e900eb3c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:07.094257 [ 2711 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:07.094368 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:07.423201 [ 3093 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:07.638817 [ 2726 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:07.686108 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:08.095404 [ 3133 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:08.095504 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:08.424071 [ 2806 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:08.593055 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:08.630273 [ 30753 ] {a290845a-a18f-4453-820e-c0137ce656f0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42146) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:08.631695 [ 30753 ] {a290845a-a18f-4453-820e-c0137ce656f0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:08.639823 [ 2760 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:09.096405 [ 2853 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:09.096556 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:09.122933 [ 29516 ] {0c0b48fb-b194-4dbb-963f-e3a250d1d437} executeQuery: Code: 10. DB::Exception: Column `key` not found in table test_3.alter_00147 (1d49ba0d-947e-4bac-a37d-f7710298dc8f). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42138) (comment: 01483_merge_table_join_and_group_by.sql) (in query: SELECT * FROM m INNER JOIN b USING(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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:0: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x0000000019550889 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001a91f82d 6. ./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&) @ 0x0000000019afa90a 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000019ae1fec 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000019ae1cc7 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000019e44cd3 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::ReadFromMerge::createPlanForTable(std::shared_ptr const&, DB::SelectQueryInfo&, DB::QueryProcessingStage::Enum, unsigned long, std::tuple, std::shared_ptr, String> const&, std::vector>&&, std::optional const&, std::shared_ptr, unsigned long) const @ 0x00000000192df4c5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:603: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x00000000192d78ae 12. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000192d394f 13. ./build_docker/./src/Storages/StorageMerge.cpp:1582: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x00000000192e77e3 14. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000001aa0e283 15. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000001aa0e0f1 16. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1732 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 2025.06.12 19:12:09.124321 [ 29516 ] {0c0b48fb-b194-4dbb-963f-e3a250d1d437} TCPHandler: Code: 10. DB::Exception: Column `key` not found in table test_3.alter_00147 (1d49ba0d-947e-4bac-a37d-f7710298dc8f). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:0: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x0000000019550889 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001a91f82d 6. ./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&) @ 0x0000000019afa90a 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000019ae1fec 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000019ae1cc7 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000019e44cd3 10. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::ReadFromMerge::createPlanForTable(std::shared_ptr const&, DB::SelectQueryInfo&, DB::QueryProcessingStage::Enum, unsigned long, std::tuple, std::shared_ptr, String> const&, std::vector>&&, std::optional const&, std::shared_ptr, unsigned long) const @ 0x00000000192df4c5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:603: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x00000000192d78ae 12. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000192d394f 13. ./build_docker/./src/Storages/StorageMerge.cpp:1582: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x00000000192e77e3 14. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000001aa0e283 15. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000001aa0e0f1 16. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001a9f1732 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a90ef9a 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90da90 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 2025.06.12 19:12:09.424790 [ 2832 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:09.433912 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:09.640674 [ 2869 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:10.097224 [ 2713 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:10.097336 [ 2780 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:10.222168 [ 30753 ] {0fb8d08f-0f51-4026-8eb6-0ce96f94797f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42208) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:10.223753 [ 30753 ] {0fb8d08f-0f51-4026-8eb6-0ce96f94797f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:10.281122 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:10.425523 [ 2858 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:10.641384 [ 2783 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:10.984537 [ 29516 ] {7a8d9143-2ee2-4e5b-b54c-bb135996b0c1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42224) (comment: 02783_date_predicate_optimizations.sql) (in query: SELECT * FROM source WHERE toYYYYMM(ts) = 202112;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 2025.06.12 19:12:10.985936 [ 29516 ] {7a8d9143-2ee2-4e5b-b54c-bb135996b0c1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bee097 11. ./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&) @ 0x0000000019bef01f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f4fd10 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f50064 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019beb9d6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019beb5d5 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&) @ 0x0000000019ab0a94 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 @ 0x0000000019aabed2 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c06257 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9746e1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9b3583 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a978cd0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:178: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c024ed 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 2025.06.12 19:12:11.098220 [ 2887 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:11.098219 [ 2989 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:11.116735 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:11.426256 [ 3131 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:11.642232 [ 2969 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:11.701273 [ 30753 ] {5afc07db-a487-4556-b983-ece5c9a90f12} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42260) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:11.702184 [ 30753 ] {5afc07db-a487-4556-b983-ece5c9a90f12} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:11.946055 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:12.099004 [ 2748 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:12.099239 [ 3041 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:12.427180 [ 3135 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:12.643017 [ 2808 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:12.795311 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:13.099706 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.099890 [ 2853 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.178996 [ 30753 ] {ff355458-f558-4890-8b06-5ae46c67f398} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46190) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:13.180111 [ 30753 ] {ff355458-f558-4890-8b06-5ae46c67f398} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:13.394197 [ 29516 ] {2daa11a4-8c8d-4492-a8f0-530e870fdb7d} executeQuery: Code: 291. DB::Exception: Path 'data_*_{_partition_id}.csv' contains globs, so the table is in readonly mode. (DATABASE_ACCESS_DENIED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46180) (comment: 03037_s3_write_to_globbed_partitioned_path.sql) (in query: insert into function s3('http://localhost:11111/test/data_*_{_partition_id}.csv') partition by number % 3 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000016374fcb 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a787b7d 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d41ab4 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44ee1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:13.395102 [ 29516 ] {2daa11a4-8c8d-4492-a8f0-530e870fdb7d} TCPHandler: Code: 291. DB::Exception: Path 'data_*_{_partition_id}.csv' contains globs, so the table is in readonly mode. (DATABASE_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007611d00 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000016374fcb 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a787b7d 6. ./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*) @ 0x0000000017d3e634 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d3f598 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d41ab4 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d44ee1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:13.496919 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.643912 [ 2997 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.675691 [ 17160 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.676690 [ 2804 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.676753 [ 3181 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.676915 [ 2779 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.677273 [ 2782 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.677729 [ 2962 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.677760 [ 2780 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.677958 [ 3053 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.678163 [ 3070 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.678414 [ 3086 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.678950 [ 2981 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.717485 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:13.746396 [ 2810 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.746687 [ 3103 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.746783 [ 2968 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.746956 [ 3121 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.747085 [ 2792 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.747353 [ 2891 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.747467 [ 3008 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.747707 [ 3116 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.747798 [ 3001 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.748046 [ 2889 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.748400 [ 2794 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.748596 [ 2967 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.748723 [ 2856 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:13.749558 [ 3150 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.749700 [ 3142 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.749746 [ 3129 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.749908 [ 3071 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.750176 [ 3125 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.750829 [ 3061 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751019 [ 3088 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751032 [ 3052 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751061 [ 2684 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751118 [ 3081 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751125 [ 3091 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751210 [ 2877 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751312 [ 2879 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751654 [ 2691 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751269 [ 2829 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751733 [ 2947 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751768 [ 3185 ] {} test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751965 [ 3113 ] {} test_9.quorum1 (e4e2b33f-3d2d-459e-8d1e-407a5c530dcb): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.751973 [ 3182 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752001 [ 3111 ] {} test_9.rep_data (843bbcbe-99b5-42d1-85b3-eed8ef79861a): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752002 [ 2820 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752019 [ 2912 ] {} test_9.rep_data (843bbcbe-99b5-42d1-85b3-eed8ef79861a): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752016 [ 2862 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752070 [ 3026 ] {} test_9.quorum1 (e4e2b33f-3d2d-459e-8d1e-407a5c530dcb): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752170 [ 2749 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752557 [ 3186 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752607 [ 3073 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752758 [ 2790 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.752972 [ 2809 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.753017 [ 3190 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.753170 [ 2858 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.753375 [ 2689 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.791068 [ 3150 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.839976 [ 3142 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.840047 [ 2719 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.840722 [ 3071 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.841836 [ 2728 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:13.842217 [ 3091 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:14.100532 [ 3128 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:14.100546 [ 3049 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:14.497728 [ 3161 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:14.560901 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:14.644593 [ 2883 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:14.830645 [ 31269 ] {0bce6410-1b4d-4bee-8f72-3e4e24205723} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46252) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:14.831588 [ 31269 ] {0bce6410-1b4d-4bee-8f72-3e4e24205723} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:15.101376 [ 3030 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:15.101400 [ 2970 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:15.499290 [ 3197 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:15.510198 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:15.645570 [ 3022 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:16.102651 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:16.102772 [ 3100 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:16.371692 [ 30753 ] {00bdefd2-a69b-44bb-a56c-4d3b4eb2839c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46286) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:16.372942 [ 30753 ] {00bdefd2-a69b-44bb-a56c-4d3b4eb2839c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:16.418235 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:16.500169 [ 3127 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:16.647260 [ 2706 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:17.103699 [ 2853 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:17.103715 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:17.259236 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:17.500929 [ 2694 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:17.648404 [ 2959 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:17.922044 [ 30753 ] {297a1fec-3b54-4584-90bd-96cc964891c4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46332) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:17.923551 [ 30753 ] {297a1fec-3b54-4584-90bd-96cc964891c4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:18.104827 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:18.104801 [ 3154 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:18.114612 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:18.501776 [ 3107 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:18.649437 [ 2735 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:18.944258 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:19.105833 [ 2886 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:19.106064 [ 2972 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:19.502756 [ 3134 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:19.650563 [ 2931 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:19.732289 [ 30753 ] {0db99ec1-4dee-44ca-8569-169ce2ca88f0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46386) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:19.733382 [ 30753 ] {0db99ec1-4dee-44ca-8569-169ce2ca88f0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:19.773041 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:20.106975 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:20.107100 [ 2815 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:20.503453 [ 2730 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:20.612269 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:20.651472 [ 3171 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:21.108190 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:21.108208 [ 2880 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:21.451939 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:21.467925 [ 30753 ] {e9635ab8-b8b2-4da7-ab40-99f628f4e945} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46442) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:21.468916 [ 30753 ] {e9635ab8-b8b2-4da7-ab40-99f628f4e945} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:21.504444 [ 3073 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:21.652452 [ 2961 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:22.109237 [ 3182 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:22.109263 [ 3150 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:22.294028 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:22.505400 [ 3009 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:22.653279 [ 2779 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:22.960272 [ 30753 ] {d426dfb1-f95b-4b11-ba57-c1da96642cdc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53986) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:22.961392 [ 30753 ] {d426dfb1-f95b-4b11-ba57-c1da96642cdc} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:23.110292 [ 3087 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:23.110335 [ 3091 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:23.125488 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:23.506126 [ 2913 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:23.654136 [ 2986 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:23.958213 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:24.111431 [ 2852 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.111545 [ 3038 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.507080 [ 3119 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.655181 [ 2695 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.790357 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:24.790666 [ 3146 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.790826 [ 2953 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.790902 [ 3183 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.790925 [ 2737 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.791038 [ 2836 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.793394 [ 3189 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.793524 [ 2744 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.793588 [ 3183 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.793650 [ 3145 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.793777 [ 3093 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.794327 [ 3139 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.796253 [ 2793 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.796538 [ 2753 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.796952 [ 3116 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.796898 [ 3095 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.797192 [ 2787 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.797649 [ 3017 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.797850 [ 2889 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.798064 [ 2933 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.798535 [ 3072 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.799280 [ 3099 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.799356 [ 2969 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.799856 [ 2940 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.799853 [ 3054 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.800020 [ 2983 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.800217 [ 3056 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.800736 [ 3080 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.801283 [ 2810 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:24.802940 [ 3130 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.803835 [ 2836 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.804031 [ 3146 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.804180 [ 2953 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.804411 [ 2702 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.804446 [ 2784 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.804530 [ 3130 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.805665 [ 2784 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:24.872866 [ 30753 ] {f3a2210e-176c-4abd-ad70-1ac984f8603d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54032) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:24.874075 [ 30753 ] {f3a2210e-176c-4abd-ad70-1ac984f8603d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:25.071609 [ 29516 ] {c729bf52-04e4-459d-887b-318e593fdd13} executeQuery: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/test_3/test_02887/quorum. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:46260) (comment: 02887_insert_quorum_wo_keeper_retries.sql) (in query: CREATE TABLE quorum1 (`x` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_02887/quorum', '1') ORDER BY x SETTINGS index_granularity = 54047, 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 = 526781558, compact_parts_max_bytes_to_buffer = 475049723, compact_parts_max_granules_to_buffer = 240, compact_parts_merge_max_bytes_to_prefetch_part = 28774698, merge_max_block_size = 11704, 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 = 11184210, concurrent_part_removal_threshold = 74, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 30200, primary_key_compress_block_size = 65309), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:468: zkutil::ZooKeeper::createAncestors(String const&) @ 0x000000001add0721 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createTableIfNotExists(std::shared_ptr const&) @ 0x0000000019338aa2 7. ./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) @ 0x0000000019335b3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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&) @ 0x0000000019e40427 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b183 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:25.072531 [ 29516 ] {c729bf52-04e4-459d-887b-318e593fdd13} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/test_3/test_02887/quorum. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:468: zkutil::ZooKeeper::createAncestors(String const&) @ 0x000000001add0721 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createTableIfNotExists(std::shared_ptr const&) @ 0x0000000019338aa2 7. ./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) @ 0x0000000019335b3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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&) @ 0x0000000019e40427 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b183 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:25.112134 [ 3126 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:25.112447 [ 3163 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:25.507815 [ 2910 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:25.631197 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:25.655937 [ 2885 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:26.112902 [ 2817 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:26.113261 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:26.457237 [ 23927 ] {7d372ae1-ce54-4178-af48-b68b1632ea50} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54090) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:26.459029 [ 23927 ] {7d372ae1-ce54-4178-af48-b68b1632ea50} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:26.471403 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:26.508542 [ 3061 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:26.656735 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:27.114049 [ 2955 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:27.114329 [ 2786 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:27.306338 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:27.509583 [ 2989 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:27.657957 [ 2926 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:28.086038 [ 30981 ] {02b78c4f-e970-4b66-ac3c-0f965a1c68ae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54142) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:28.088372 [ 30981 ] {02b78c4f-e970-4b66-ac3c-0f965a1c68ae} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:28.115045 [ 3148 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:28.115228 [ 2810 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:28.127706 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:28.510655 [ 3094 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:28.659233 [ 2870 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:28.954063 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:29.115847 [ 3090 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:29.116070 [ 2917 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:29.511287 [ 2798 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:29.567555 [ 30753 ] {78d78765-581d-4f5b-99e4-0059615fb711} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54184) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:29.569288 [ 30753 ] {78d78765-581d-4f5b-99e4-0059615fb711} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:29.659920 [ 3056 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:29.828084 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:30.117209 [ 2701 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:30.117215 [ 3002 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:30.512425 [ 2920 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:30.660695 [ 2855 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:30.671202 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:31.118100 [ 3173 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:31.118687 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:31.131783 [ 30981 ] {16b9d5a6-aa06-4800-bc98-227733487d42} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54248) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:31.133666 [ 30981 ] {16b9d5a6-aa06-4800-bc98-227733487d42} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:31.513450 [ 2790 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:31.524717 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:31.661883 [ 2797 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:32.119158 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:32.119794 [ 2803 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:32.365873 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:32.514374 [ 3072 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:32.599772 [ 30753 ] {80be3f37-ffbd-4652-89d5-a0a20466926b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55366) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:32.600823 [ 30753 ] {80be3f37-ffbd-4652-89d5-a0a20466926b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:32.662924 [ 2845 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.120014 [ 2839 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.120658 [ 2743 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.196962 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:33.515450 [ 2968 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.663705 [ 2846 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.961260 [ 2884 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.961361 [ 2984 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.961572 [ 2936 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.961645 [ 2850 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.962894 [ 3045 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.963148 [ 3193 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.963235 [ 3176 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.963612 [ 2755 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.964014 [ 3084 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.963988 [ 2744 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.964313 [ 2717 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.964879 [ 3008 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.964989 [ 2837 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.965275 [ 3106 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.965699 [ 2873 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.966016 [ 2731 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.966135 [ 2814 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.966560 [ 2938 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.966896 [ 2798 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.967175 [ 3115 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.967432 [ 3085 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.967990 [ 2758 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.968227 [ 3139 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:33.969164 [ 2729 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.969177 [ 2736 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.969247 [ 2756 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.969313 [ 2708 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.969242 [ 2793 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.969250 [ 3105 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.969356 [ 2919 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.970048 [ 2793 ] {} test_3.i20203_2 (d9f23c98-0e4b-41ec-b568-37d65d2f2266): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_3/01715_background_checker_i20203/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.970406 [ 3102 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.971012 [ 2827 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.971048 [ 2998 ] {} test_3.i20203_2 (d9f23c98-0e4b-41ec-b568-37d65d2f2266): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.971495 [ 3122 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:33.971525 [ 2756 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:34.063230 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:34.120637 [ 2767 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:34.121313 [ 2935 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:34.419091 [ 30753 ] {835b85e3-22bc-44ce-85bf-8cf982162a4e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55402) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:34.420621 [ 30753 ] {835b85e3-22bc-44ce-85bf-8cf982162a4e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:34.516207 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:34.664701 [ 3111 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:34.912436 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:35.121340 [ 3040 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:35.122003 [ 3003 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:35.516948 [ 2926 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:35.665534 [ 3016 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:35.780685 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:35.898305 [ 30753 ] {1552d82d-c0eb-4f01-b46b-611ede094f9d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55460) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:35.951685 [ 30753 ] {1552d82d-c0eb-4f01-b46b-611ede094f9d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:36.122105 [ 2976 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:36.122675 [ 3059 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:36.517600 [ 3099 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:36.605440 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:36.666319 [ 3080 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:37.122839 [ 3122 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:37.123262 [ 2756 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:37.450011 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:37.518858 [ 2799 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:37.540960 [ 30753 ] {f7145aed-40e3-4306-bcf3-20c7859ff288} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55492) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:37.542321 [ 30753 ] {f7145aed-40e3-4306-bcf3-20c7859ff288} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:37.667058 [ 2755 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:38.123472 [ 2959 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:38.123934 [ 3005 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:38.295690 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:38.519757 [ 3014 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:38.667834 [ 3058 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:39.124265 [ 2720 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:39.125051 [ 2997 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:39.147119 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:39.173445 [ 30753 ] {020df4b8-547e-471b-b825-4c0f9b49ccb7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55520) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:39.174405 [ 30753 ] {020df4b8-547e-471b-b825-4c0f9b49ccb7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:39.520499 [ 2918 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:39.708465 [ 2842 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:39.990848 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:40.125970 [ 2847 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:40.126380 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:40.521397 [ 2866 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:40.600528 [ 30753 ] {da43609a-d8c5-4740-a403-034c6023db16} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=782). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55562) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: SELECT is_done as is_running FROM system.mutations WHERE database==currentDatabase() AND table=='t1'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:40.601710 [ 30753 ] {da43609a-d8c5-4740-a403-034c6023db16} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=782). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:40.655424 [ 29580 ] {8f68736e-9733-49da-9c18-09e9eb860b32} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55568) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:40.656830 [ 29580 ] {8f68736e-9733-49da-9c18-09e9eb860b32} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:40.709853 [ 2967 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:40.862447 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:41.126949 [ 2812 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:41.127400 [ 2745 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:41.522412 [ 2736 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:41.699393 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:41.711004 [ 2747 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:42.110813 [ 30753 ] {934f5b63-f505-4840-a2b9-079b3df9083d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53842) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:42.113336 [ 30753 ] {934f5b63-f505-4840-a2b9-079b3df9083d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:42.127783 [ 2731 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:42.128229 [ 2769 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:42.523533 [ 2865 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:42.529758 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:42.711978 [ 3136 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:42.899402 [ 30980 ] {33def139-3eb5-420c-9f57-050006dc5cc1} 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.10057.altinitytest (altinity build)) (from [::1]:53882) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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_ @ 0x00000000091bd72c 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&&) @ 0x00000000091ada73 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000091a8dff 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a7878 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a6216 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:12:42.900049 [ 30980 ] {33def139-3eb5-420c-9f57-050006dc5cc1} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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_ @ 0x00000000091bd72c 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&&) @ 0x00000000091ada73 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000091a8dff 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a7878 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a6216 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:12:43.058116 [ 2923 ] {} test_3.i20203_2 (ReplicatedMergeTreePartCheckThread): No replica has part covering all_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.06.12 19:12:43.080606 [ 2923 ] {} test_3.i20203_2 (ReplicatedMergeTreePartCheckThread): Part all_0_0_0 is lost forever. 2025.06.12 19:12:43.128906 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.129037 [ 2832 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.225555 [ 30980 ] {204f1628-2cce-4d43-9ffb-d9a11c21fd65} 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.10057.altinitytest (altinity build)) (from [::1]:53882) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x000000000918efec 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_ @ 0x000000000921ef6d 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&&) @ 0x00000000091b0da7 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000091a8dff 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a7878 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a6216 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:12:43.226286 [ 30980 ] {204f1628-2cce-4d43-9ffb-d9a11c21fd65} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x000000000918efec 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_ @ 0x000000000921ef6d 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&&) @ 0x00000000091b0da7 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000091a8dff 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a7878 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a6216 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:12:43.359624 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:43.524473 [ 3077 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.568785 [ 30980 ] {212f6c82-72d2-4618-b94a-322fd9331d4b} 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.10057.altinitytest (altinity build)) (from [::1]:53882) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x00000000091876fe 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&&) @ 0x00000000091b3ff0 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000091a8dff 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a7878 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a6216 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:12:43.569415 [ 30980 ] {212f6c82-72d2-4618-b94a-322fd9331d4b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x00000000091876fe 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&&) @ 0x00000000091b3ff0 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000091a8dff 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a7878 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091a6216 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:12:43.703825 [ 30753 ] {123a634c-4ca6-41bc-bf58-00f9a909f880} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53888) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:43.704935 [ 30753 ] {123a634c-4ca6-41bc-bf58-00f9a909f880} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:43.712849 [ 2978 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.813381 [ 17168 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.814407 [ 2913 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.814564 [ 2992 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.814977 [ 3169 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.815082 [ 2947 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.815362 [ 2725 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.816077 [ 3081 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.816294 [ 3069 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.816862 [ 2829 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.817332 [ 3190 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.817366 [ 3150 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.817680 [ 3125 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.817800 [ 2950 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.818013 [ 3087 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.818902 [ 3195 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.822226 [ 3053 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.822327 [ 2754 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.822384 [ 3118 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.822390 [ 2763 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.822449 [ 2728 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.822598 [ 2786 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.824503 [ 3049 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/source/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.836863 [ 2842 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.836967 [ 3071 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.837018 [ 2691 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.837070 [ 2955 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.837709 [ 2874 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.837717 [ 2875 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.837744 [ 3052 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.837781 [ 2986 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.837730 [ 3060 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:12:43.838666 [ 2831 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.838816 [ 2943 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.839044 [ 2863 ] {} test_9.clear_column2 (8381d2fd-f81f-4c9f-b575-7114c5a93f57): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.839533 [ 3142 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.839685 [ 2762 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.839762 [ 3047 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.839833 [ 3091 ] {} test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840017 [ 2783 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840229 [ 2989 ] {} test_9.rep_data (843bbcbe-99b5-42d1-85b3-eed8ef79861a): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840230 [ 3118 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840375 [ 2763 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840512 [ 2987 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840536 [ 2719 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840078 [ 2852 ] {} test_9.rep_data (843bbcbe-99b5-42d1-85b3-eed8ef79861a): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840576 [ 2857 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840288 [ 2795 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840539 [ 2847 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840639 [ 3019 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.840898 [ 3108 ] {} test_9.quorum1 (e4e2b33f-3d2d-459e-8d1e-407a5c530dcb): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.841716 [ 2887 ] {} test_9.quorum1 (e4e2b33f-3d2d-459e-8d1e-407a5c530dcb): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.841997 [ 3137 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.842103 [ 2991 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.842370 [ 3167 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.842511 [ 2739 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.843145 [ 2985 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:43.935113 [ 30980 ] {f580c565-c26b-4e4d-ad70-e617f2c7d40c} 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.10057.altinitytest (altinity build)) (from [::1]:53882) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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_ @ 0x00000000090bc0ac 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&&) @ 0x00000000090ac3f3 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000090a777f 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a61f8 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a4b96 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:12:43.935922 [ 30980 ] {f580c565-c26b-4e4d-ad70-e617f2c7d40c} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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_ @ 0x00000000090bc0ac 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&&) @ 0x00000000090ac3f3 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000090a777f 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a61f8 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a4b96 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:12:44.129792 [ 2873 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:44.129850 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:44.141222 [ 30980 ] {6fdc9741-d2e9-4437-b2fb-4e1a4ac4d8ab} 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.10057.altinitytest (altinity build)) (from [::1]:53882) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x000000000908c164 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_ @ 0x000000000911da8d 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&&) @ 0x00000000090af727 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000090a777f 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a61f8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a4b96 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:12:44.141866 [ 30980 ] {6fdc9741-d2e9-4437-b2fb-4e1a4ac4d8ab} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x000000000908c164 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_ @ 0x000000000911da8d 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&&) @ 0x00000000090af727 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000090a777f 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a61f8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a4b96 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 2025.06.12 19:12:44.209163 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:44.391725 [ 30980 ] {3add3291-b9fe-4ddc-86d5-a1e7e7d33ed0} 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.10057.altinitytest (altinity build)) (from [::1]:53882) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x0000000009082c93 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&&) @ 0x00000000090b2970 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000090a777f 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a61f8 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a4b96 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:12:44.392718 [ 30980 ] {3add3291-b9fe-4ddc-86d5-a1e7e7d33ed0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 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) @ 0x0000000009082c93 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&&) @ 0x00000000090b2970 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000090a777f 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a61f8 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090a4b96 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 2025.06.12 19:12:44.525290 [ 3056 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:44.713815 [ 2951 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:44.737674 [ 31184 ] {1368de3f-f6dd-4687-9dce-e829bbf2711b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53914) (comment: 01048_window_view_parser.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:44.738261 [ 31184 ] {1368de3f-f6dd-4687-9dce-e829bbf2711b} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:45.047531 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:45.130573 [ 2909 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:45.130677 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:45.178084 [ 31184 ] {f4bb9c14-5211-4124-a3e6-e7c4a1cbecef} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53932) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:45.179045 [ 31184 ] {f4bb9c14-5211-4124-a3e6-e7c4a1cbecef} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:45.192821 [ 29580 ] {0596b1c6-d0f1-4c3a-ac24-c41530a051eb} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53920) (comment: 03206_is_null_constant_result_old_analyzer_bug.sql) (in query: set allow_experimental_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:45.193656 [ 29580 ] {0596b1c6-d0f1-4c3a-ac24-c41530a051eb} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016825963 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175ae236 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e43c8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:45.525966 [ 3177 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:45.714669 [ 2713 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:45.933389 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:46.131222 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:46.131243 [ 3108 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:46.526676 [ 2848 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:46.715356 [ 2927 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:46.760230 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:47.132075 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:47.132236 [ 2940 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:47.171641 [ 31184 ] {7d29397e-43dc-4c0c-9a51-48213d7d36e6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53972) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:47.173044 [ 31184 ] {7d29397e-43dc-4c0c-9a51-48213d7d36e6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:47.527481 [ 2970 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:47.601333 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:47.716372 [ 2825 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:48.133600 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:48.133604 [ 2873 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:48.471087 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:48.528289 [ 2850 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:48.635675 [ 4083 ] {3c91da70-8841-4627-9e82-d4d494060d18} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54058) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:48.636570 [ 4083 ] {3c91da70-8841-4627-9e82-d4d494060d18} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:48.717493 [ 2958 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:49.134922 [ 2855 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:49.134986 [ 3057 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:49.305915 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:49.529005 [ 2767 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:49.718710 [ 2860 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:50.135978 [ 2757 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:50.135969 [ 3187 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:50.146972 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:50.365137 [ 29580 ] {cf460343-9e34-4005-b39d-7df6783906bc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54094) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:50.366454 [ 29580 ] {cf460343-9e34-4005-b39d-7df6783906bc} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:50.529758 [ 2809 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:50.719641 [ 2847 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:50.995364 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:51.137006 [ 3178 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:51.137245 [ 2851 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:51.530758 [ 3071 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:51.722039 [ 2928 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:51.918112 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:52.137871 [ 3021 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:52.138309 [ 2698 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:52.180873 [ 29580 ] {ca0b3ed5-822d-49b4-8870-0722fe745418} 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.10057.altinitytest (altinity build)) (from [::1]:54144) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:52.182100 [ 29580 ] {ca0b3ed5-822d-49b4-8870-0722fe745418} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:52.531618 [ 2962 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:52.723047 [ 2955 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:52.748674 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:53.139122 [ 2812 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:53.139305 [ 3060 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:53.532443 [ 2746 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:53.538996 [ 29580 ] {74076378-d3ef-4bcb-b86f-a951612762e6} executeQuery: Code: 43. DB::Exception: Illegal column for first argument of function hopEnd. Must be a Tuple(DataTime, DataTime): In scope SELECT hopEnd(CAST(tuple([[[(20, 20), (50, 20), (50, 50), (20, 50)], [(30, 30), (50, 50), (50, 30)]], [[(20, 20), (50, 20), (50, 50), (20, 50)], [(30, 30), (50, 50), (50, 30)]], [[(20, 20), (50, 20), (50, 50), (20, 50)], [(30, 30), (50, 50), (50, 30)]]]), 'Tuple(MultiPolygon)')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48434) (comment: 03014_window_view_crash.sql) (in query: SELECT hopEnd(tuple([[[(20,20),(50,20),(50,50),(20,50)],[(30,30),(50,50),(50,30)]], [[(20,20),(50,20),(50,50),(20,50)],[(30,30),(50,50),(50,30)]], [[(20,20),(50,20),(50,50),(20,50)],[(30,30),(50,50),(50,30)]]])::Tuple(MultiPolygon));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. DB::(anonymous namespace)::executeWindowBound(COW::immutable_ptr const&, unsigned long, String const&) @ 0x00000000086fe6e0 5. DB::(anonymous namespace)::FunctionTimeWindow<(DB::(anonymous namespace)::TimeWindowFunctionName)5>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008700011 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 19:12:53.539865 [ 29580 ] {74076378-d3ef-4bcb-b86f-a951612762e6} TCPHandler: Code: 43. DB::Exception: Illegal column for first argument of function hopEnd. Must be a Tuple(DataTime, DataTime): In scope SELECT hopEnd(CAST(tuple([[[(20, 20), (50, 20), (50, 50), (20, 50)], [(30, 30), (50, 50), (50, 30)]], [[(20, 20), (50, 20), (50, 50), (20, 50)], [(30, 30), (50, 50), (50, 30)]], [[(20, 20), (50, 20), (50, 50), (20, 50)], [(30, 30), (50, 50), (50, 30)]]]), 'Tuple(MultiPolygon)')). (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. DB::(anonymous namespace)::executeWindowBound(COW::immutable_ptr const&, unsigned long, String const&) @ 0x00000000086fe6e0 5. DB::(anonymous namespace)::FunctionTimeWindow<(DB::(anonymous namespace)::TimeWindowFunctionName)5>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008700011 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007611264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007633a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087115e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087110be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008711574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087121d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008713eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bacff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017499bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749891b 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cb9a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174915d4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 2025.06.12 19:12:53.571331 [ 4083 ] {5effd115-2f7f-4c74-a24f-d68115c59bb7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48448) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: SELECT is_done as is_running FROM system.mutations WHERE database==currentDatabase() AND table=='t1'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:53.572271 [ 4083 ] {5effd115-2f7f-4c74-a24f-d68115c59bb7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:53.600719 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:53.623429 [ 29580 ] {3afc90e3-c5a3-403b-988c-674304c7e770} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48458) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:53.624428 [ 29580 ] {3afc90e3-c5a3-403b-988c-674304c7e770} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:53.723776 [ 2895 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:54.140137 [ 2871 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:54.140668 [ 2936 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:54.499832 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:54.533418 [ 3103 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:54.724730 [ 2872 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:55.097844 [ 29580 ] {d711c90c-409a-4928-93bf-3972a2c47499} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48508) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:55.099173 [ 29580 ] {d711c90c-409a-4928-93bf-3972a2c47499} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:55.141020 [ 3030 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:55.141521 [ 3102 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:55.329662 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:55.534237 [ 2760 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:55.725641 [ 2878 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:56.142022 [ 3015 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:56.142361 [ 2840 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:56.168943 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:56.535040 [ 2798 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:56.726721 [ 3156 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:57.006906 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:57.143119 [ 2850 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:57.143219 [ 2964 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:57.535903 [ 2755 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:57.727673 [ 2977 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:57.842704 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:58.089967 [ 29516 ] {a5c9911f-cc8e-4961-863c-54b0d5e0ff3b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading from part /var/lib/clickhouse/store/777/7779edca-b815-4b88-adca-6384948e7a52/5_0_52_1/ in table test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52) located on disk default of type local, from mark 0 with max_rows_to_read = 17880): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48548) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5ae03 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d205 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d47e 16. DB::ReadBuffer::next() @ 0x0000000007b3417b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000019b92367 18. ./src/Common/CacheBase.h:152: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000019b90efc 19. ./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()() @ 0x0000000019b93e6d 20. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000019b9755d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019b9404d 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:58.144034 [ 3017 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:58.144031 [ 3120 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:58.361746 [ 29516 ] {a5c9911f-cc8e-4961-863c-54b0d5e0ff3b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading from part /var/lib/clickhouse/store/777/7779edca-b815-4b88-adca-6384948e7a52/5_0_52_1/ in table test_9.alter_table_4 (7779edca-b815-4b88-adca-6384948e7a52) located on disk default of type local, from mark 0 with max_rows_to_read = 17880): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5ae03 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d205 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d5d47e 16. DB::ReadBuffer::next() @ 0x0000000007b3417b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000019b92367 18. ./src/Common/CacheBase.h:152: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000019b90efc 19. ./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()() @ 0x0000000019b93e6d 20. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000019b9755d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019b9404d 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 27. __tsan_thread_start_func @ 0x000000000758af2f 28. ? @ 0x00007f4e69e13ac3 29. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:58.536718 [ 2791 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:58.676745 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:58.728696 [ 3165 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:59.145239 [ 2914 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:59.145557 [ 2902 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:59.512263 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:12:59.537549 [ 2900 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:12:59.729607 [ 3025 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:00.037439 [ 4083 ] {b6cdc3dd-0a83-4710-a03f-8a982f340fda} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48606) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:00.039347 [ 4083 ] {b6cdc3dd-0a83-4710-a03f-8a982f340fda} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:00.145983 [ 3058 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:00.146814 [ 2717 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:00.342851 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:00.538386 [ 2909 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:00.759720 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.146978 [ 3039 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.147597 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.269080 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:01.354084 [ 2697 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.354620 [ 3141 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.355287 [ 2751 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.355291 [ 2752 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.355297 [ 2874 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.355762 [ 2697 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.357150 [ 2810 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.357373 [ 2767 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.357691 [ 3141 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.357875 [ 3184 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.358098 [ 2921 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.358299 [ 3194 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.358738 [ 2810 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.359061 [ 2938 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.359177 [ 2881 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.359333 [ 2920 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.359352 [ 3023 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.359521 [ 2775 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.359685 [ 3034 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.359855 [ 2946 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.360145 [ 3084 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.360340 [ 2860 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.360793 [ 2828 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.361070 [ 2815 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.361191 [ 2752 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.361392 [ 3044 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.361518 [ 3024 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.361837 [ 2761 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.362162 [ 2908 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.362824 [ 3177 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.363131 [ 2931 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.363351 [ 2994 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.363637 [ 2720 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.364001 [ 2696 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.364275 [ 2714 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:01.397237 [ 17182 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Operation timeout (deadline of 10000 ms already expired) for path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, String&&) @ 0x000000000fee0246 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, int&, String&&) @ 0x000000001ae5a68c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae50340 6. ./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*) @ 0x000000001ae58593 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 9. __tsan_thread_start_func @ 0x000000000758af2f 10. ? @ 0x00007f4e69e13ac3 11. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.401832 [ 29580 ] {90f8bb83-f68a-4950-bd3a-a03a7ac789ea} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48528) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: CREATE TABLE t_async_insert_cleanup (`KeyID` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup', '{replica}') ORDER BY KeyID SETTINGS cleanup_delay_period = 1, cleanup_delay_period_random_add = 1, cleanup_thread_preferred_points_per_iteration = 0, replicated_deduplication_window_for_async_inserts = 10, index_granularity = 43788, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.5477809309959412, 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 = 187956291, compact_parts_max_granules_to_buffer = 98, compact_parts_merge_max_bytes_to_prefetch_part = 8769353, merge_max_block_size = 16456, old_parts_lifetime = 406., 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 = 4891357, concurrent_part_removal_threshold = 76, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 72242, primary_key_compress_block_size = 55078), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:468: zkutil::ZooKeeper::createAncestors(String const&) @ 0x000000001add0721 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createTableIfNotExists(std::shared_ptr const&) @ 0x0000000019338aa2 7. ./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) @ 0x0000000019335b3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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&) @ 0x0000000019e40427 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b183 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:01.403709 [ 29580 ] {90f8bb83-f68a-4950-bd3a-a03a7ac789ea} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:468: zkutil::ZooKeeper::createAncestors(String const&) @ 0x000000001add0721 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createTableIfNotExists(std::shared_ptr const&) @ 0x0000000019338aa2 7. ./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) @ 0x0000000019335b3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.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&) @ 0x0000000019e40427 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e3b183 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001646f004 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 @ 0x00000000191ba866 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4a659 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 24. __tsan_thread_start_func @ 0x000000000758af2f 25. ? @ 0x00007f4e69e13ac3 26. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:01.421565 [ 2933 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.474285 [ 2933 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.539291 [ 2802 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:01.673191 [ 29577 ] {94cc76f7-63ba-4fef-8381-9fc3f5e47f56} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48668) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:01.674383 [ 29577 ] {94cc76f7-63ba-4fef-8381-9fc3f5e47f56} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:01.761016 [ 2899 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:02.013744 [ 29516 ] {cd47854d-e4cd-4880-9b43-789cd421ea3d} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:48674) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:02.015120 [ 29516 ] {cd47854d-e4cd-4880-9b43-789cd421ea3d} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:02.148036 [ 2942 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:02.148452 [ 2801 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:02.183910 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:02.539982 [ 3179 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:02.590429 [ 29577 ] {f356d509-fa30-4aac-bc10-a6cf6ae1245b} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32956) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:02.592724 [ 29577 ] {f356d509-fa30-4aac-bc10-a6cf6ae1245b} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:02.762085 [ 3116 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:03.034624 [ 29516 ] {944fe6ea-045b-49f0-b55e-e312d6e9ad1a} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32968) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.035662 [ 29516 ] {944fe6ea-045b-49f0-b55e-e312d6e9ad1a} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.039374 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.148910 [ 2709 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:03.149161 [ 3117 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:03.186685 [ 29577 ] {d1af806a-bb18-4210-9ca2-280efe661c9b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32978) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.187848 [ 29577 ] {d1af806a-bb18-4210-9ca2-280efe661c9b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.449390 [ 29577 ] {2dda6309-5d2c-4e06-8191-de3b9055153f} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:32990) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.450556 [ 29577 ] {2dda6309-5d2c-4e06-8191-de3b9055153f} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.540673 [ 3154 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:03.763142 [ 2841 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:03.864635 [ 29516 ] {d5d686b0-e3b2-42ad-b988-fd8088567836} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33004) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.865927 [ 29516 ] {d5d686b0-e3b2-42ad-b988-fd8088567836} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:03.875710 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:04.149664 [ 3057 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:04.150065 [ 2855 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:04.288152 [ 29516 ] {d0dcea8e-ef34-4485-994f-e160a87a63a1} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33014) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:04.289059 [ 29516 ] {d0dcea8e-ef34-4485-994f-e160a87a63a1} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:04.541399 [ 2869 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:04.699082 [ 29577 ] {8682ec3a-09fa-4b83-b314-ca3e235b17cf} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33030) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:04.700184 [ 29577 ] {8682ec3a-09fa-4b83-b314-ca3e235b17cf} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:04.714103 [ 29516 ] {5749a6af-c0be-4850-81be-3d04affa7d01} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33026) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:04.715417 [ 29516 ] {5749a6af-c0be-4850-81be-3d04affa7d01} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:04.737772 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:04.763906 [ 2892 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:05.113224 [ 29516 ] {884022ad-1ee9-4a27-b274-0517dbfcfdad} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33044) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:05.114774 [ 29516 ] {884022ad-1ee9-4a27-b274-0517dbfcfdad} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:05.174828 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:05.238191 [ 2997 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:05.522847 [ 29516 ] {fba61c9f-1a4c-4a18-b18e-5cd04603fc16} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33058) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:05.523904 [ 29516 ] {fba61c9f-1a4c-4a18-b18e-5cd04603fc16} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:05.542367 [ 2816 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:05.572940 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:05.764800 [ 2763 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:05.956385 [ 29516 ] {ff443fa9-13a7-40d3-8c0e-dddb36e853cd} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33078) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:05.957709 [ 29516 ] {ff443fa9-13a7-40d3-8c0e-dddb36e853cd} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:06.175857 [ 3032 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:06.239451 [ 2695 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:06.378100 [ 31269 ] {8f7cf5d0-fe38-4d3b-bf3f-18db1e087ac4} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33112) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:06.379255 [ 31269 ] {8f7cf5d0-fe38-4d3b-bf3f-18db1e087ac4} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:06.414307 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:06.543360 [ 3084 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:06.766054 [ 3080 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:06.852883 [ 29577 ] {4dfa5d31-dc3d-4c3c-8382-5f4716d039bf} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33134) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:06.853983 [ 29577 ] {4dfa5d31-dc3d-4c3c-8382-5f4716d039bf} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:06.933711 [ 29516 ] {f6659ef8-8ad7-4eeb-8951-94012d9edbb7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/ba1/ba153c9d-0129-4209-ab37-275e8cf118ba/-1_0_126_2_124/ in table test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba) located on disk default of type local, from mark 0 with max_rows_to_read = 40131): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33084) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a954baa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:13:06.960708 [ 29516 ] {f6659ef8-8ad7-4eeb-8951-94012d9edbb7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/ba1/ba153c9d-0129-4209-ab37-275e8cf118ba/-1_0_126_2_124/ in table test_9.alter_table_8 (ba153c9d-0129-4209-ab37-275e8cf118ba) located on disk default of type local, from mark 0 with max_rows_to_read = 40131): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a954baa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:13:07.176658 [ 2789 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:07.240465 [ 2891 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:07.252511 [ 29577 ] {d667852b-34b3-4e7e-80e8-561c90a0029c} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33152) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:07.253888 [ 29577 ] {d667852b-34b3-4e7e-80e8-561c90a0029c} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:07.262900 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:07.544356 [ 3140 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:07.674712 [ 29516 ] {627befe0-7eb7-4406-aed6-1eca637b96b4} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33174) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:07.675742 [ 29516 ] {627befe0-7eb7-4406-aed6-1eca637b96b4} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:07.767059 [ 2839 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:08.084603 [ 29516 ] {dcda7ccf-a272-40ef-bb56-7a7e922d5192} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33182) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.085422 [ 29516 ] {dcda7ccf-a272-40ef-bb56-7a7e922d5192} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.093883 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.177398 [ 3036 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:08.241474 [ 2930 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:08.343165 [ 29516 ] {33a702ab-788a-438e-93b4-9d506049940d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33200) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.345076 [ 29516 ] {33a702ab-788a-438e-93b4-9d506049940d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.534812 [ 29516 ] {eba80b7c-094b-465a-9a1a-a9a866306654} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33210) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.535619 [ 29516 ] {eba80b7c-094b-465a-9a1a-a9a866306654} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.545255 [ 3117 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:08.768016 [ 3005 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:08.925608 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.998255 [ 29516 ] {49ff515b-776a-4cc9-92c5-42fa45fde13b} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33230) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:08.999220 [ 29516 ] {49ff515b-776a-4cc9-92c5-42fa45fde13b} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:09.178798 [ 2806 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.242378 [ 2855 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.377336 [ 17255 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.378164 [ 2884 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.378364 [ 3065 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.378754 [ 2690 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.378800 [ 2903 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.378957 [ 2907 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.379607 [ 2965 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.379808 [ 3193 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.379970 [ 2914 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.380179 [ 2888 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.380541 [ 3197 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.380740 [ 2716 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.381063 [ 3124 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.381184 [ 2923 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.381572 [ 2906 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.381782 [ 3025 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.381983 [ 3106 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.382348 [ 2735 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.382597 [ 2682 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.383056 [ 2910 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.383427 [ 3160 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.383680 [ 3058 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.384318 [ 2885 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.384728 [ 3132 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:09.385570 [ 2951 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.385607 [ 2905 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.385664 [ 2901 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.385642 [ 3136 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.385751 [ 3002 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.385774 [ 2959 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.386143 [ 3192 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.387074 [ 2959 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.408560 [ 29516 ] {5eb1b130-3c00-49f6-b4c0-aaf6cc692712} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33244) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:09.409643 [ 29516 ] {5eb1b130-3c00-49f6-b4c0-aaf6cc692712} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:09.545903 [ 2780 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.768918 [ 3148 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:09.771291 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:09.806783 [ 31269 ] {c1947755-0652-4ebd-8ecc-efe179b64a47} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33262) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:09.808056 [ 31269 ] {c1947755-0652-4ebd-8ecc-efe179b64a47} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:09.868488 [ 29516 ] {b2d945db-7fbc-4bdd-8b56-61c5e91fd175} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33264) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:09.869268 [ 29516 ] {b2d945db-7fbc-4bdd-8b56-61c5e91fd175} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:10.180957 [ 2968 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:10.280578 [ 29516 ] {ea201b2b-64ff-4771-b5c0-f0f05dba6283} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33276) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:10.281448 [ 29516 ] {ea201b2b-64ff-4771-b5c0-f0f05dba6283} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:10.315402 [ 2698 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:10.546782 [ 2856 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:10.605426 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:10.683541 [ 29516 ] {a1927747-0a5d-4be8-823f-e3448da402f7} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33294) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:10.684433 [ 29516 ] {a1927747-0a5d-4be8-823f-e3448da402f7} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:10.769644 [ 2688 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:11.083236 [ 31269 ] {60e98311-b221-41e6-a879-629b2dbf6397} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33312) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:11.086648 [ 31269 ] {60e98311-b221-41e6-a879-629b2dbf6397} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:11.181640 [ 2839 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:11.316082 [ 2708 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:11.441737 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:11.503175 [ 31269 ] {afb61f24-b262-4702-aff9-4f392dc6cee3} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33336) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:11.504388 [ 31269 ] {afb61f24-b262-4702-aff9-4f392dc6cee3} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:11.547851 [ 2850 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:11.626158 [ 29516 ] {6b28fb22-efee-4b78-a5ea-aa0dc8b503f1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33314) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:11.627503 [ 29516 ] {6b28fb22-efee-4b78-a5ea-aa0dc8b503f1} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:11.770394 [ 2744 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:11.934467 [ 31269 ] {d2221563-183e-46c7-9dd2-9fdb34b236d6} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40192) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:11.935558 [ 31269 ] {d2221563-183e-46c7-9dd2-9fdb34b236d6} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:12.182344 [ 2721 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:12.268301 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:12.317462 [ 3046 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:12.460027 [ 29516 ] {89c2b005-39d6-4f80-b4a8-5d7cad667832} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40220) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:12.461890 [ 29516 ] {89c2b005-39d6-4f80-b4a8-5d7cad667832} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:12.549852 [ 3142 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:12.772611 [ 2971 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:12.926642 [ 31269 ] {f69aafb7-710f-4745-8ec7-ae1b8d94fd69} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40234) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:12.927870 [ 31269 ] {f69aafb7-710f-4745-8ec7-ae1b8d94fd69} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.104377 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.183278 [ 3132 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:13.318729 [ 2991 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:13.346320 [ 30981 ] {91eb2508-efcd-48a4-a54b-2aba15a2af79} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40264) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.347489 [ 30981 ] {91eb2508-efcd-48a4-a54b-2aba15a2af79} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.551025 [ 3043 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:13.574853 [ 23927 ] {c9cd8dd4-23e8-45e1-8349-b9fe88a60987} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40238) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.576015 [ 23927 ] {c9cd8dd4-23e8-45e1-8349-b9fe88a60987} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.768874 [ 23927 ] {60b0af9d-1549-4b4d-9e8f-2ff5a7d9f409} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40280) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.770011 [ 23927 ] {60b0af9d-1549-4b4d-9e8f-2ff5a7d9f409} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.774049 [ 2869 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:13.887621 [ 30981 ] {d294ca8c-f006-4f5c-9bc0-1bf2dbcf337b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40296) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: SELECT is_done as is_running FROM system.mutations WHERE database==currentDatabase() AND table=='t1'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.888622 [ 30981 ] {d294ca8c-f006-4f5c-9bc0-1bf2dbcf337b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:13.933768 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:14.185409 [ 2761 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:14.186660 [ 23927 ] {cdb6f3e5-da54-454d-a832-ff9ca0dabc65} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40306) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:14.188843 [ 23927 ] {cdb6f3e5-da54-454d-a832-ff9ca0dabc65} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:14.319436 [ 2857 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:14.551713 [ 2946 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:14.607903 [ 23927 ] {50cdb4cf-ba80-4b6c-9aae-a0524f5daa92} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40322) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:14.609309 [ 23927 ] {50cdb4cf-ba80-4b6c-9aae-a0524f5daa92} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:14.775278 [ 2963 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:14.790933 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.014606 [ 23927 ] {bdc6c720-193f-407d-88d1-b512b013d067} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40358) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.015676 [ 23927 ] {bdc6c720-193f-407d-88d1-b512b013d067} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.052225 [ 30981 ] {c26497fe-aa46-49ad-9a98-98460b76e438} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40370) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.053479 [ 30981 ] {c26497fe-aa46-49ad-9a98-98460b76e438} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.186550 [ 2968 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:15.320368 [ 3112 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:15.453868 [ 23927 ] {60b51e12-fb0d-4e0c-a9a5-60c89c58b642} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40386) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.455191 [ 23927 ] {60b51e12-fb0d-4e0c-a9a5-60c89c58b642} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.552612 [ 2981 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:15.616866 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.776202 [ 3069 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:15.873172 [ 30981 ] {0084d48d-f281-4475-87af-7ada70cd1d7e} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40408) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:15.874112 [ 30981 ] {0084d48d-f281-4475-87af-7ada70cd1d7e} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:16.187741 [ 2846 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:16.321113 [ 2693 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:16.364867 [ 23927 ] {4268b41c-497b-4aa5-bf37-a391b8739839} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40412) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:16.365597 [ 23927 ] {4268b41c-497b-4aa5-bf37-a391b8739839} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:16.443086 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:16.553392 [ 3156 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:16.777106 [ 2983 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:16.833252 [ 30980 ] {62242b43-3264-4c5f-8311-032878615ec1} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40440) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:16.834561 [ 30980 ] {62242b43-3264-4c5f-8311-032878615ec1} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:17.077986 [ 30981 ] {a0170072-32f6-41a9-ac92-a05cd5d52101} 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.10057.altinitytest (altinity build)) (from [::1]:40414) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:17.079393 [ 30981 ] {a0170072-32f6-41a9-ac92-a05cd5d52101} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:17.188552 [ 3136 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:17.279300 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:17.289155 [ 30981 ] {682f4e2c-b28f-47f0-bcbb-af04731f6dd7} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40462) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:17.289972 [ 30981 ] {682f4e2c-b28f-47f0-bcbb-af04731f6dd7} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:17.321831 [ 3113 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:17.554367 [ 3160 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:17.699977 [ 23927 ] {0d079a9f-37a1-494b-a787-328b665b7cc2} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40476) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:17.701372 [ 23927 ] {0d079a9f-37a1-494b-a787-328b665b7cc2} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:17.778054 [ 2770 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:18.111740 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:18.121776 [ 30981 ] {a2f2667f-3131-4db6-bd13-1b3f8345f6d6} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40502) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:18.122764 [ 30981 ] {a2f2667f-3131-4db6-bd13-1b3f8345f6d6} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:18.189313 [ 3177 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:18.322619 [ 2833 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:18.540703 [ 30981 ] {71a2abb1-0778-4611-8fde-72d3281a9b50} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40512) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:18.541774 [ 30981 ] {71a2abb1-0778-4611-8fde-72d3281a9b50} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:18.555084 [ 3128 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:18.778925 [ 2963 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:18.929698 [ 23927 ] {4221037e-6826-47d5-956f-45634c4a095a} 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.10057.altinitytest (altinity build)) (from [::1]:40504) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:18.930971 [ 23927 ] {4221037e-6826-47d5-956f-45634c4a095a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:18.970308 [ 30980 ] {f30807d3-5c5c-49f5-99af-635faba8fb01} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40532) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:18.971624 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:19.053085 [ 30980 ] {f30807d3-5c5c-49f5-99af-635faba8fb01} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:19.189987 [ 2737 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:19.323444 [ 2976 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:19.474774 [ 23927 ] {a7def941-8fd8-4f7a-9243-78e0a318d834} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40554) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:19.475846 [ 23927 ] {a7def941-8fd8-4f7a-9243-78e0a318d834} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:19.555916 [ 3051 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:19.779981 [ 2839 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:19.814302 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:19.905866 [ 30981 ] {37a6087d-cf66-4904-84fb-1c4e3f65633f} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40584) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:19.947151 [ 30981 ] {37a6087d-cf66-4904-84fb-1c4e3f65633f} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:20.190898 [ 3036 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:20.325130 [ 2979 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:20.365042 [ 30981 ] {f93790ac-2e7d-4763-bfae-075d79d09ddf} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40600) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:20.365973 [ 30981 ] {f93790ac-2e7d-4763-bfae-075d79d09ddf} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:20.556726 [ 2840 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:20.661026 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:20.780902 [ 2734 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:20.782671 [ 30980 ] {5519def4-910c-44aa-a6bb-232a580f8aab} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40608) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:20.784268 [ 30980 ] {5519def4-910c-44aa-a6bb-232a580f8aab} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:20.821665 [ 23927 ] {7b4d260d-c7e7-4b14-93bd-c1f11989e752} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40598) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:20.822886 [ 23927 ] {7b4d260d-c7e7-4b14-93bd-c1f11989e752} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:21.191714 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:21.196391 [ 23927 ] {b7757e13-80ed-4d38-9a5c-7150d1d9c219} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40612) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:21.197458 [ 23927 ] {b7757e13-80ed-4d38-9a5c-7150d1d9c219} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:21.326004 [ 2960 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:21.502749 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:21.557597 [ 2988 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:21.613828 [ 23927 ] {06b76798-24c2-4863-87a9-3d52f7069185} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:40624) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:21.614959 [ 23927 ] {06b76798-24c2-4863-87a9-3d52f7069185} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:21.781914 [ 2910 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:22.073003 [ 23927 ] {b9520648-7e7a-455a-a23b-c50f1fc5576e} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58480) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:22.077838 [ 23927 ] {b9520648-7e7a-455a-a23b-c50f1fc5576e} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:22.193051 [ 2716 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:22.272308 [ 23927 ] {719a7684-86cf-41fd-93b6-0535cadfc760} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58482) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:22.273403 [ 23927 ] {719a7684-86cf-41fd-93b6-0535cadfc760} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:22.327476 [ 3061 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:22.336406 [ 30981 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:22.487088 [ 23927 ] {42e177e4-7b1c-497f-9e5f-5761c631b6e9} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58492) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:22.488633 [ 23927 ] {42e177e4-7b1c-497f-9e5f-5761c631b6e9} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:22.558567 [ 2997 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:22.783158 [ 2703 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:22.914148 [ 23927 ] {b02b25a9-976c-449a-b70b-1c243c775a82} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58524) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:22.915426 [ 23927 ] {b02b25a9-976c-449a-b70b-1c243c775a82} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:23.170823 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:23.194031 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:23.320691 [ 23927 ] {5b322a24-70e7-4406-9608-5d3e363cd31b} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58536) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:23.321726 [ 23927 ] {5b322a24-70e7-4406-9608-5d3e363cd31b} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:23.328331 [ 3063 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:23.559242 [ 3124 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:23.733221 [ 30980 ] {fd284a78-4435-405c-a845-5b253e1b71a2} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58560) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:23.734254 [ 30980 ] {fd284a78-4435-405c-a845-5b253e1b71a2} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:23.783934 [ 3006 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:23.789928 [ 30981 ] {6d981de9-8e14-420c-a297-8d29a3ebf1b9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58552) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:23.791081 [ 30981 ] {6d981de9-8e14-420c-a297-8d29a3ebf1b9} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:24.029358 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:24.144443 [ 23927 ] {a1134600-61dd-4aa2-acb3-61e9cf5b3a1f} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58588) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:24.145262 [ 23927 ] {a1134600-61dd-4aa2-acb3-61e9cf5b3a1f} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:24.194856 [ 2792 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.329069 [ 2999 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.559894 [ 3018 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.585916 [ 23927 ] {96dd2a00-58ef-4ef4-a290-065b4d5f0dfc} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58594) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:24.586908 [ 23927 ] {96dd2a00-58ef-4ef4-a290-065b4d5f0dfc} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:24.784545 [ 3096 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.852259 [ 23927 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:24.881847 [ 2799 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.881949 [ 2873 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.882290 [ 3029 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.882828 [ 2825 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.883225 [ 2878 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.883240 [ 2710 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.883247 [ 3000 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.884036 [ 2709 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.884344 [ 2840 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.884796 [ 3180 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.885429 [ 2808 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.885717 [ 2844 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.886074 [ 2693 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.886344 [ 2759 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.886547 [ 3035 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.886929 [ 2760 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.887326 [ 3156 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.887839 [ 3102 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.888029 [ 3133 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.888447 [ 2850 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.889903 [ 3015 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.890252 [ 2969 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.890816 [ 2977 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.891349 [ 2889 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.891721 [ 3116 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:24.892539 [ 3033 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.892621 [ 2966 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.892656 [ 2995 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.892733 [ 3076 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.894172 [ 3114 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:24.989934 [ 30981 ] {cabd775e-85c7-4892-9744-ffa12c3c6d4a} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58610) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:24.991301 [ 30981 ] {cabd775e-85c7-4892-9744-ffa12c3c6d4a} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:25.195689 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:25.329756 [ 2886 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:25.394228 [ 30980 ] {934cf86a-f53d-4e1f-9f6d-90fa7385ab02} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58622) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:25.395541 [ 30980 ] {934cf86a-f53d-4e1f-9f6d-90fa7385ab02} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:25.469598 [ 30981 ] {dda06faf-4e4b-4b8f-b433-cb7d874023ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58614) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:25.470903 [ 30981 ] {dda06faf-4e4b-4b8f-b433-cb7d874023ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:25.560665 [ 2718 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:25.702744 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:25.785322 [ 3011 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:25.800244 [ 30980 ] {f07ae850-0780-4a6c-b9fe-2569f1a27a2e} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58642) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:25.801078 [ 30980 ] {f07ae850-0780-4a6c-b9fe-2569f1a27a2e} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:26.196426 [ 2913 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:26.225436 [ 30980 ] {4ec82c37-27d3-453a-ae30-4ed886a27f05} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58644) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:26.226717 [ 30980 ] {4ec82c37-27d3-453a-ae30-4ed886a27f05} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:26.330508 [ 2968 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:26.540525 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:26.561371 [ 3013 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:26.642789 [ 30980 ] {5462eb8a-b6eb-4469-8853-8d346940e06f} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58662) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:26.648767 [ 30980 ] {5462eb8a-b6eb-4469-8853-8d346940e06f} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:26.786204 [ 3078 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:27.026219 [ 30980 ] {a0a96cb7-46de-4639-aa90-579691a80aea} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58670) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:27.027435 [ 30980 ] {a0a96cb7-46de-4639-aa90-579691a80aea} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:27.053964 [ 31184 ] {a8a1180e-19ae-4f73-a9e9-a2d4f83f8743} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58684) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:27.054913 [ 31184 ] {a8a1180e-19ae-4f73-a9e9-a2d4f83f8743} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:27.197180 [ 3054 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:27.331437 [ 2899 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:27.377575 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:27.463440 [ 31184 ] {577a4757-8185-4aa4-8bd5-63c9c83f6513} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58698) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:27.464381 [ 31184 ] {577a4757-8185-4aa4-8bd5-63c9c83f6513} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:27.562532 [ 3125 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:27.787065 [ 2822 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:27.930162 [ 30980 ] {aeb81e95-adef-4477-9d33-61f9ca5aa11f} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58708) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:27.932274 [ 30980 ] {aeb81e95-adef-4477-9d33-61f9ca5aa11f} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:28.198078 [ 2700 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:28.214023 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:28.332356 [ 2827 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:28.362931 [ 30980 ] {529988e7-4627-4b28-9923-f9fa669c143b} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58738) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:28.364130 [ 30980 ] {529988e7-4627-4b28-9923-f9fa669c143b} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:28.475025 [ 29580 ] {5b606edd-e4be-4590-876b-211072c0d900} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58756) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:28.476323 [ 29580 ] {5b606edd-e4be-4590-876b-211072c0d900} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:28.563353 [ 2793 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:28.771502 [ 30980 ] {dff36b4c-3bad-4695-9f0b-e2f2c3bee146} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58770) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:28.772810 [ 30980 ] {dff36b4c-3bad-4695-9f0b-e2f2c3bee146} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:28.788059 [ 3064 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:29.130998 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:29.188198 [ 30980 ] {41ed7352-9c0d-4c42-9457-91df92443a12} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58790) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:29.189043 [ 30980 ] {41ed7352-9c0d-4c42-9457-91df92443a12} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:29.199062 [ 2932 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:29.333081 [ 2988 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:29.564147 [ 3102 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:29.619110 [ 30980 ] {19aade3f-4e0f-458d-bb7b-ba7175fc2ab0} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58802) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:29.620414 [ 30980 ] {19aade3f-4e0f-458d-bb7b-ba7175fc2ab0} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:29.789630 [ 2796 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:29.968346 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.007438 [ 30980 ] {759b3792-3c29-4022-b3c6-17fdfc2d2c77} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58808) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.008605 [ 30980 ] {759b3792-3c29-4022-b3c6-17fdfc2d2c77} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.058422 [ 31184 ] {dc69965a-8898-4a86-b025-084eb446a620} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58828) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.059578 [ 31184 ] {dc69965a-8898-4a86-b025-084eb446a620} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.199915 [ 2876 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:30.374992 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:30.537927 [ 30980 ] {03192e6c-fe50-45ca-9abc-dbe0e25f55f5} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58834) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.540723 [ 30980 ] {03192e6c-fe50-45ca-9abc-dbe0e25f55f5} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.565018 [ 3182 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:30.791112 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:30.795805 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.975991 [ 30980 ] {0d121ce7-680c-4c48-bd38-664dc875cba9} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58854) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:30.976868 [ 30980 ] {0d121ce7-680c-4c48-bd38-664dc875cba9} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:31.201036 [ 2724 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:31.376171 [ 3003 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:31.401066 [ 30980 ] {0cbb8e0b-fd9d-465b-aa68-e03cff3a63b6} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58872) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:31.402351 [ 30980 ] {0cbb8e0b-fd9d-465b-aa68-e03cff3a63b6} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:31.566197 [ 2778 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:31.670013 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:31.791997 [ 3024 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:31.899549 [ 29580 ] {926192e0-f5a3-4776-bfd9-64b1e9272d08} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58896) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:31.900557 [ 29580 ] {926192e0-f5a3-4776-bfd9-64b1e9272d08} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:31.907403 [ 31184 ] {a989a0cc-3ff6-433c-9a09-47d0f586fd79} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58876) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:31.908860 [ 31184 ] {a989a0cc-3ff6-433c-9a09-47d0f586fd79} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:32.201970 [ 3149 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:32.344415 [ 29580 ] {88062400-1673-45be-86ac-1b1ffc072d91} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52138) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:32.345349 [ 29580 ] {88062400-1673-45be-86ac-1b1ffc072d91} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:32.377070 [ 3053 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:32.567016 [ 3041 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:32.573829 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:32.792752 [ 2942 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:32.847571 [ 31184 ] {ccce57bb-2075-4763-a862-4ff5b1392c4e} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52166) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:32.848559 [ 31184 ] {ccce57bb-2075-4763-a862-4ff5b1392c4e} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:33.203081 [ 2804 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:33.275525 [ 29580 ] {de4c2bc6-765c-4fa7-8bf5-f91a4b187c5c} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52180) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:33.276644 [ 29580 ] {de4c2bc6-765c-4fa7-8bf5-f91a4b187c5c} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:33.377889 [ 2898 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:33.393090 [ 30753 ] {9c91de10-70d9-4cc2-94ec-cabf77084fba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52182) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:33.394183 [ 30753 ] {9c91de10-70d9-4cc2-94ec-cabf77084fba} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:33.401569 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:33.567821 [ 2683 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:33.706067 [ 31184 ] {6b68b830-835c-4c66-b675-55189274a150} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52202) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:33.707125 [ 31184 ] {6b68b830-835c-4c66-b675-55189274a150} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:33.793500 [ 2979 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:34.116772 [ 31184 ] {c8520d17-2549-4489-95d1-9cf62c700e58} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52218) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:34.117567 [ 31184 ] {c8520d17-2549-4489-95d1-9cf62c700e58} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:34.204081 [ 2964 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:34.297936 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:34.378792 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:34.544735 [ 31184 ] {be586e80-99d2-48f2-a0f1-ccb09d3eef7d} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52244) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:34.568592 [ 2883 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:34.579817 [ 31184 ] {be586e80-99d2-48f2-a0f1-ccb09d3eef7d} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:34.794383 [ 2755 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:34.929285 [ 31184 ] {c7e45a15-fee7-4ab1-94ec-61a30f8e9d63} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52246) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:34.931023 [ 31184 ] {c7e45a15-fee7-4ab1-94ec-61a30f8e9d63} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:35.018705 [ 29580 ] {c44131f7-4fda-4cd5-8b0b-60a8dce1f26c} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52250) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:35.019880 [ 29580 ] {c44131f7-4fda-4cd5-8b0b-60a8dce1f26c} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:35.128928 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:35.205551 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:35.379679 [ 2972 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:35.429987 [ 31184 ] {e22ffa8f-866c-464f-8d71-d7b8de601ded} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52282) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:35.431013 [ 31184 ] {e22ffa8f-866c-464f-8d71-d7b8de601ded} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:35.569886 [ 2874 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:35.795632 [ 2869 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:35.839777 [ 31184 ] {81046aff-32b2-4055-86f6-9cc56c05c698} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52292) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:35.840562 [ 31184 ] {81046aff-32b2-4055-86f6-9cc56c05c698} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:35.955954 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:36.206857 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:36.261599 [ 31184 ] {078ac2e5-2ed2-4af7-aaa3-fa518c359d61} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52326) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:36.262646 [ 31184 ] {078ac2e5-2ed2-4af7-aaa3-fa518c359d61} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:36.380502 [ 2762 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:36.455967 [ 29580 ] {8409a5bb-a1a6-4d2d-92c6-96b84db1ffd5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52332) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:36.457149 [ 29580 ] {8409a5bb-a1a6-4d2d-92c6-96b84db1ffd5} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:36.570939 [ 3024 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:36.681075 [ 31184 ] {35fad165-a709-4c61-ad2e-78424379cfea} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52346) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:36.682332 [ 31184 ] {35fad165-a709-4c61-ad2e-78424379cfea} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:36.796396 [ 3038 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:36.823659 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.096486 [ 29580 ] {6987eeb4-f1d0-44d6-a47f-4b5c0709805b} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52354) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.097414 [ 29580 ] {6987eeb4-f1d0-44d6-a47f-4b5c0709805b} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.207685 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.381253 [ 2976 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.514869 [ 31184 ] {99de78a1-54a1-4765-8a87-aa9fc9b35779} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52366) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.516270 [ 31184 ] {99de78a1-54a1-4765-8a87-aa9fc9b35779} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.571613 [ 3021 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.676620 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.797389 [ 3084 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.910757 [ 17253 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.911743 [ 2836 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.911949 [ 3051 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.912265 [ 3188 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.913753 [ 3001 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.914082 [ 2688 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.951783 [ 30753 ] {1b2a538e-e2ab-4891-a22d-8e0bd6195fca} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52396) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.952658 [ 30753 ] {1b2a538e-e2ab-4891-a22d-8e0bd6195fca} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.961679 [ 2807 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.961948 [ 2773 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.962239 [ 3074 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.962620 [ 3112 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.962704 [ 3020 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.962386 [ 2756 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.962871 [ 2748 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.963251 [ 2812 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.963515 [ 3095 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.963713 [ 2736 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.963905 [ 2804 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.964248 [ 3090 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.964519 [ 2871 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.964653 [ 3018 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.964914 [ 2839 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.964997 [ 3164 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.965387 [ 2794 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.965793 [ 3097 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:37.966809 [ 2980 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.966964 [ 3052 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.967039 [ 3094 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.967116 [ 2705 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.968453 [ 2911 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.968595 [ 2777 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.968646 [ 2866 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.969751 [ 31184 ] {31b25d87-2ade-4bf8-8424-853fa0d19253} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52380) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:37.970000 [ 2777 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:37.971079 [ 31184 ] {31b25d87-2ade-4bf8-8424-853fa0d19253} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:38.208568 [ 2905 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:38.374391 [ 31184 ] {5dc97ef8-03cc-438a-9bc1-5f5c743db7f2} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52410) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:38.375410 [ 31184 ] {5dc97ef8-03cc-438a-9bc1-5f5c743db7f2} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:38.381888 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:38.509557 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:38.572274 [ 3118 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:38.798127 [ 3182 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:38.804241 [ 31184 ] {100cc17b-42a2-4b90-9a09-efef27f853f5} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52428) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:38.805607 [ 31184 ] {100cc17b-42a2-4b90-9a09-efef27f853f5} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:39.206311 [ 31184 ] {067c1041-dc4d-4ab4-a2c0-30e7f5e9be72} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52446) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:39.207808 [ 31184 ] {067c1041-dc4d-4ab4-a2c0-30e7f5e9be72} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:39.209248 [ 2770 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:39.340984 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:39.382724 [ 2797 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:39.414644 [ 31184 ] {4cadc11f-1278-4e69-b056-40660302680d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52470) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:39.415670 [ 31184 ] {4cadc11f-1278-4e69-b056-40660302680d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:39.573043 [ 2682 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:39.609472 [ 31184 ] {96540edd-d15b-48b4-8343-eaa84a19aeb1} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52480) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:39.610418 [ 31184 ] {96540edd-d15b-48b4-8343-eaa84a19aeb1} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:39.799024 [ 2761 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:40.020244 [ 31184 ] {52fcad8e-7fd6-4705-8abb-70236830ae85} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52492) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:40.021180 [ 31184 ] {52fcad8e-7fd6-4705-8abb-70236830ae85} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:40.173266 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:40.209972 [ 3129 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:40.383442 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:40.428592 [ 31184 ] {a13fbb86-6763-4622-8d86-5d383e2947bb} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52504) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:40.429784 [ 31184 ] {a13fbb86-6763-4622-8d86-5d383e2947bb} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:40.573764 [ 3172 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:40.799755 [ 2783 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:40.837107 [ 30753 ] {4c485846-73df-4f9e-b0d4-29408eef7f33} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52524) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:40.838065 [ 30753 ] {4c485846-73df-4f9e-b0d4-29408eef7f33} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:41.007011 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:41.024501 [ 29580 ] {cd1a4585-ea40-4859-995e-40a0c0d9021a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52516) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:41.025909 [ 29580 ] {cd1a4585-ea40-4859-995e-40a0c0d9021a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:41.210662 [ 3079 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:41.248361 [ 31184 ] {f0f7a126-9859-4c1e-bec0-f0f5cc359c95} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52540) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:41.249703 [ 31184 ] {f0f7a126-9859-4c1e-bec0-f0f5cc359c95} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:41.384118 [ 3019 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:41.574716 [ 2894 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:41.676372 [ 31184 ] {f7dade89-1ea6-4b5d-b181-586d864209a9} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52556) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:41.677787 [ 31184 ] {f7dade89-1ea6-4b5d-b181-586d864209a9} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:41.800412 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:41.858975 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:42.100792 [ 31184 ] {4d81f970-1b1d-4838-8a05-9777d3b7739c} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51678) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:42.103641 [ 31184 ] {4d81f970-1b1d-4838-8a05-9777d3b7739c} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:42.211654 [ 3003 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:42.384899 [ 3193 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:42.535769 [ 29580 ] {5402e340-ab10-4d61-ae50-39ae47a80290} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51692) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:42.536677 [ 29580 ] {5402e340-ab10-4d61-ae50-39ae47a80290} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:42.575436 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:42.729956 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:42.801606 [ 2860 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:42.816104 [ 3282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {751051e6-adca-4665-9806-ed7c89ce0982::202506_1_157_51}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:42.942916 [ 31184 ] {9985b93d-b2d5-4545-a416-72475b5c1a9a} 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.10057.altinitytest (altinity build)) (from [::1]:51682) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:42.943913 [ 31184 ] {9985b93d-b2d5-4545-a416-72475b5c1a9a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:42.962131 [ 29580 ] {d678dfd9-d10c-4202-b4be-007a26efd5e4} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51716) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:43.014027 [ 29580 ] {d678dfd9-d10c-4202-b4be-007a26efd5e4} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:43.212730 [ 2817 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:43.385985 [ 3065 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:43.418636 [ 31184 ] {bceae4ec-f570-47e8-aa68-c6690ee2be57} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51730) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:43.419899 [ 31184 ] {bceae4ec-f570-47e8-aa68-c6690ee2be57} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:43.554247 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:43.576354 [ 2926 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:43.802599 [ 3197 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:43.841993 [ 29580 ] {874bdfaa-dec2-43a0-8746-038d57facbc9} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51758) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:43.843676 [ 29580 ] {874bdfaa-dec2-43a0-8746-038d57facbc9} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:44.215004 [ 3063 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:44.250960 [ 31184 ] {77ad9a5e-7acd-4158-8d01-954b9a35cd40} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51762) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:44.251880 [ 31184 ] {77ad9a5e-7acd-4158-8d01-954b9a35cd40} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:44.433133 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:44.457507 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:44.464449 [ 29580 ] {e393f039-fa38-44ae-b396-b80c8588ebb3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51764) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:44.465752 [ 29580 ] {e393f039-fa38-44ae-b396-b80c8588ebb3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:44.577240 [ 2782 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:44.655436 [ 31184 ] {0a090eb4-1326-4cf2-adf7-c50ce992fdae} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51782) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: insert into t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:44.656388 [ 31184 ] {0a090eb4-1326-4cf2-adf7-c50ce992fdae} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696da0 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d3b3af 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:311: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017547667 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x0000000017547cc5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000182151b2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:44.803476 [ 3173 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:45.215774 [ 2916 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:45.273902 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:45.458320 [ 2950 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:45.577925 [ 3006 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:45.804293 [ 2943 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:45.906762 [ 31184 ] {1d92b5e5-4389-4d34-b4e7-4fccdcf51641} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51824) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:45.908058 [ 31184 ] {1d92b5e5-4389-4d34-b4e7-4fccdcf51641} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:46.112439 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:46.216608 [ 2953 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:46.459295 [ 2767 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:46.578667 [ 2986 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:46.805151 [ 3092 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:46.951163 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:47.217595 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:47.460257 [ 3040 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:47.579532 [ 3053 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:47.630589 [ 29580 ] {2b2a062e-7f43-40ef-b2bb-fb60c716a50d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51868) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:47.632080 [ 29580 ] {2b2a062e-7f43-40ef-b2bb-fb60c716a50d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:47.779545 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:47.805946 [ 2968 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.218337 [ 3188 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.503288 [ 2777 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.580404 [ 2764 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.639387 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:48.664924 [ 3025 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.665412 [ 2714 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.665472 [ 2691 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.665551 [ 3101 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.665823 [ 2978 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.665863 [ 2972 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.665926 [ 2872 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.666003 [ 3069 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.666289 [ 2688 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.666820 [ 2888 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.667122 [ 3025 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.667343 [ 2714 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.667461 [ 3166 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.667694 [ 2827 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.668058 [ 2692 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.668256 [ 3081 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.668424 [ 2978 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.668563 [ 2708 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.668776 [ 2972 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.668966 [ 2888 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.668844 [ 3074 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.669487 [ 3103 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.669771 [ 3096 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.670013 [ 2793 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.670337 [ 2970 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.670659 [ 2736 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.670969 [ 3030 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.671197 [ 2683 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.671612 [ 2835 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.673205 [ 2710 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.673428 [ 2706 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.673944 [ 3122 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.674352 [ 3020 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:13:48.675762 [ 3049 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.676399 [ 2876 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:48.806825 [ 3076 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:49.005938 [ 3377 ] {} virtual bool DB::DDLWorker::initializeMainThread(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/task_queue/ddl/. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:468: zkutil::ZooKeeper::createAncestors(String const&) @ 0x000000001add0721 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::initializeMainThread() @ 0x0000000017683aa2 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x0000000017668863 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017686cc6 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017686be2 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:49.219491 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:49.312120 [ 29580 ] {aafde334-15c2-46ca-abd8-f47e3c0a56c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51930) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:49.313165 [ 29580 ] {aafde334-15c2-46ca-abd8-f47e3c0a56c0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:49.485177 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:49.504122 [ 2790 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:49.581102 [ 2824 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:49.881087 [ 3073 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:50.220309 [ 3023 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:50.323026 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:50.504948 [ 2946 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:50.581778 [ 2749 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:50.881871 [ 3187 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:51.154321 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:51.220979 [ 2986 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:51.505602 [ 3104 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:51.582583 [ 2868 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:51.615891 [ 31184 ] {93b5152d-94cc-48e8-bcb8-92f0565482ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:51986) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:51.617173 [ 31184 ] {93b5152d-94cc-48e8-bcb8-92f0565482ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:51.980636 [ 2705 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:52.012439 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:52.239712 [ 2793 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:52.506650 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:52.583530 [ 2836 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:52.862827 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:52.981482 [ 2694 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:53.117443 [ 31184 ] {c74710be-bae7-493e-98c5-d201e5630d95} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52004) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:53.118935 [ 31184 ] {c74710be-bae7-493e-98c5-d201e5630d95} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:53.240607 [ 3147 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:53.507531 [ 3075 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:53.584493 [ 2697 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:53.689904 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:53.982373 [ 2795 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:54.241749 [ 3158 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:54.508280 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:54.533882 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:54.585903 [ 3124 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:54.611038 [ 29580 ] {6bba0e34-26cf-4ab6-8cc9-9e8d6aaec1bb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52062) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:54.612325 [ 29580 ] {6bba0e34-26cf-4ab6-8cc9-9e8d6aaec1bb} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:54.983781 [ 2737 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:55.242757 [ 2767 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:55.370193 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:55.509076 [ 2913 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:55.680299 [ 3159 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:55.984775 [ 2953 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:56.243629 [ 3146 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:56.244001 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:56.509902 [ 2781 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:56.681539 [ 2714 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:56.985711 [ 3154 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:57.023642 [ 29580 ] {86634bb5-0e21-409c-9408-cbeb8ffa4487} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52118) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:57.024825 [ 29580 ] {86634bb5-0e21-409c-9408-cbeb8ffa4487} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:57.111810 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:57.244464 [ 2742 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:57.510847 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:57.682701 [ 2966 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:57.954176 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:57.986601 [ 2951 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:58.245327 [ 2902 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:58.511994 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:58.706739 [ 2731 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:58.781754 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:58.987341 [ 2939 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:59.016767 [ 29580 ] {21db2615-6f34-4f96-ac54-abece7b9006b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52184) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:59.017878 [ 29580 ] {21db2615-6f34-4f96-ac54-abece7b9006b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:59.246035 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:59.512770 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:59.628931 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:13:59.707500 [ 2830 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:13:59.988315 [ 2993 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:00.247051 [ 2950 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:00.485400 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:00.513524 [ 2732 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:00.557628 [ 29516 ] {882d4ca6-071a-4e6b-acf1-8b9c886b49cc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:52232) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:00.558714 [ 29516 ] {882d4ca6-071a-4e6b-acf1-8b9c886b49cc} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:00.708369 [ 3119 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:00.989262 [ 2867 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:01.247924 [ 2999 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:01.316922 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:01.514303 [ 2992 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:01.709441 [ 2998 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:01.990049 [ 2969 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:02.043247 [ 31184 ] {90c591c5-b2ff-4132-beee-e74fb40f39d3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60574) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:02.044797 [ 31184 ] {90c591c5-b2ff-4132-beee-e74fb40f39d3} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:02.152364 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:02.248962 [ 2744 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:02.515208 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:02.710363 [ 3107 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:02.985431 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:02.991190 [ 3012 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:03.249862 [ 3113 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:03.516016 [ 3106 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:03.711412 [ 2897 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:03.840068 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:03.846512 [ 29516 ] {7b0ebe0a-60b7-4afc-9c89-88b2bbde94da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60630) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:03.847946 [ 29516 ] {7b0ebe0a-60b7-4afc-9c89-88b2bbde94da} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:03.992131 [ 2717 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:04.250945 [ 2874 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:04.518314 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:04.687169 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:04.712352 [ 3167 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:04.992975 [ 2857 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:05.252720 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:05.517553 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:05.519549 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:05.713808 [ 3006 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:05.993934 [ 2976 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:06.253765 [ 2986 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:06.366990 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:06.520778 [ 2868 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:06.601626 [ 29580 ] {07457715-84b6-41af-8d00-0b95bfa7cf08} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/38b/38b1b594-8cf2-483c-bb28-07c4a85bce95/-7_0_51_1_1/ in table test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95) located on disk default of type local, from mark 1 with max_rows_to_read = 17880): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60680) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:14:06.715278 [ 3104 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:06.780033 [ 29580 ] {07457715-84b6-41af-8d00-0b95bfa7cf08} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/38b/38b1b594-8cf2-483c-bb28-07c4a85bce95/-7_0_51_1_1/ in table test_9.alter_table_1 (38b1b594-8cf2-483c-bb28-07c4a85bce95) located on disk default of type local, from mark 1 with max_rows_to_read = 17880): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:14:06.995234 [ 2777 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:07.198293 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:07.254815 [ 2793 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:07.521794 [ 3089 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:07.716139 [ 2827 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:07.996159 [ 2810 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:08.036568 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:08.151912 [ 29580 ] {b0a6070d-39ea-4991-adbc-77a5750db497} 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.10057.altinitytest (altinity build)) (from [::1]:60760) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:08.153160 [ 29580 ] {b0a6070d-39ea-4991-adbc-77a5750db497} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:08.255742 [ 3144 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:08.522753 [ 2934 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:08.717108 [ 2741 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:08.866405 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:08.997142 [ 2947 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.041336 [ 17242 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.042121 [ 3014 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.042200 [ 2790 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.042263 [ 2739 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.042378 [ 2815 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.042508 [ 2820 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.043604 [ 3169 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.044174 [ 2766 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.044314 [ 2754 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.044427 [ 3193 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.044509 [ 3169 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.044899 [ 2857 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.045666 [ 2879 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.045704 [ 2886 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.045834 [ 3023 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.045841 [ 3194 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.045944 [ 2682 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.046181 [ 2863 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.046574 [ 2719 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.046722 [ 3196 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.047113 [ 3091 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.047335 [ 3184 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.047459 [ 2860 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.047903 [ 2869 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.048265 [ 3088 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:09.049497 [ 2931 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.049631 [ 2731 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.049732 [ 2939 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.049749 [ 2685 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.049749 [ 3177 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.049769 [ 2770 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.049923 [ 3167 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.050169 [ 3158 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.051332 [ 3167 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.335359 [ 3041 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.523658 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.717846 [ 3136 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:09.725068 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:09.928007 [ 29516 ] {6f7bb03d-4f96-449a-b832-bebee9de5d01} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60784) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:09.929910 [ 29516 ] {6f7bb03d-4f96-449a-b832-bebee9de5d01} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:09.997926 [ 2825 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:10.336312 [ 3175 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:10.524435 [ 2827 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:10.548692 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:10.718518 [ 3066 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:10.999001 [ 2694 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:11.337162 [ 3102 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:11.384844 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:11.525289 [ 2923 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:11.556567 [ 29516 ] {14035a24-e536-4665-bb6a-38719193d339} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:60842) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:11.557594 [ 29516 ] {14035a24-e536-4665-bb6a-38719193d339} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:11.719216 [ 2713 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:12.001090 [ 2796 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:12.223839 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:12.337955 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:12.526458 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:12.720614 [ 2928 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:12.763437 [ 3278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_197_52}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:13.002103 [ 2950 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:13.104368 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:13.204179 [ 29516 ] {fb32c646-27b4-4322-bd94-62496a0a16fb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41084) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:13.206051 [ 29516 ] {fb32c646-27b4-4322-bd94-62496a0a16fb} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:13.339076 [ 2963 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:13.527566 [ 3021 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:13.721809 [ 3119 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:13.960139 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:14.003407 [ 3060 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:14.339978 [ 3115 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:14.528473 [ 2736 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:14.722743 [ 3117 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:14.744237 [ 29516 ] {a36808f7-1c2d-4dce-9a30-7c536e288b4b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41146) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:14.745337 [ 29516 ] {a36808f7-1c2d-4dce-9a30-7c536e288b4b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:14.793670 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:15.004301 [ 2806 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:15.340941 [ 3123 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:15.529437 [ 2971 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:15.635293 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:15.723517 [ 2903 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:16.005110 [ 3043 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:16.341813 [ 2816 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:16.480347 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:16.530199 [ 3190 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:16.673824 [ 31269 ] {a162259c-b6ba-4c9a-98ea-4f259c98ec39} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41228) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:16.675035 [ 31269 ] {a162259c-b6ba-4c9a-98ea-4f259c98ec39} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:16.724272 [ 3169 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:17.005958 [ 2908 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:17.320269 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:17.342969 [ 2974 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:17.531138 [ 2867 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:17.725398 [ 2953 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:18.006974 [ 3125 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:18.166680 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:18.199497 [ 31269 ] {e8a0adf7-07a1-4894-af5d-b84e2db3644a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41294) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:18.201062 [ 31269 ] {e8a0adf7-07a1-4894-af5d-b84e2db3644a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:18.343846 [ 2792 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:18.532116 [ 2999 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:18.726138 [ 3140 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:19.007519 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:19.007818 [ 3145 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:19.344592 [ 3126 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:19.592355 [ 3175 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:19.727379 [ 3066 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:19.882599 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:20.009532 [ 2853 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:20.345664 [ 3151 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:20.593456 [ 3103 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:20.728543 [ 2854 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:20.752316 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:21.011956 [ 2691 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:21.347142 [ 2709 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:21.612617 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:21.644080 [ 2873 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:21.729635 [ 2728 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:22.012749 [ 3016 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:22.263522 [ 31269 ] {a369e449-ac9c-4be9-8a1e-e74630a85de2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/-5_0_115_2/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 5 with max_rows_to_read = 32095): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:41334) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:14:22.348306 [ 3092 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:22.486977 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:22.499439 [ 31269 ] {a369e449-ac9c-4be9-8a1e-e74630a85de2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/ad6/ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e/-5_0_115_2/ in table test_9.alter_table_0 (ad6e2a16-4ca8-4fc5-be06-a6fa21a1e81e) located on disk default of type local, from mark 5 with max_rows_to_read = 32095): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:14:22.644986 [ 2950 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:22.730798 [ 2963 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:23.013439 [ 3121 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:23.331792 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:23.349211 [ 2980 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:23.645742 [ 2743 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:23.731708 [ 2882 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:23.985569 [ 29577 ] {3fead6a7-f93c-41ef-ae17-eec34c92c2d9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33096) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:23.987562 [ 29577 ] {3fead6a7-f93c-41ef-ae17-eec34c92c2d9} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:24.014378 [ 2872 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:24.167309 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:24.350213 [ 2889 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:24.646831 [ 2994 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:24.732498 [ 2814 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:25.012585 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:25.015502 [ 2810 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:25.351094 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:25.480455 [ 29516 ] {4cbca79e-2c75-458f-9727-38d23e440092} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33152) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:25.481460 [ 29516 ] {4cbca79e-2c75-458f-9727-38d23e440092} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:25.647560 [ 2877 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:25.733124 [ 3056 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:25.853381 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:26.016907 [ 2805 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:26.352056 [ 2831 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:26.648916 [ 2809 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:26.687362 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:26.733862 [ 3011 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:27.017795 [ 3141 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:27.136526 [ 29577 ] {6b564ca1-fdf6-435f-9bec-44637161a9a8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33202) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:27.137493 [ 29577 ] {6b564ca1-fdf6-435f-9bec-44637161a9a8} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:27.352977 [ 3013 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:27.571804 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:27.650100 [ 3131 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:27.735221 [ 2895 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:28.019910 [ 2860 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:28.354246 [ 2793 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:28.414927 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:28.605284 [ 29577 ] {abc41214-eda1-46da-9d48-f8ea6893fcc1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33258) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:28.606653 [ 29577 ] {abc41214-eda1-46da-9d48-f8ea6893fcc1} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:28.651041 [ 3126 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:28.735936 [ 2956 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:29.020882 [ 3114 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:29.305686 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:29.354975 [ 3166 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:29.651903 [ 2772 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:29.736688 [ 2684 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:30.021779 [ 2704 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:30.135653 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:30.355810 [ 3116 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:30.652905 [ 2991 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:30.737597 [ 3068 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:30.977242 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:31.022967 [ 3086 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:31.049425 [ 29577 ] {793acb4e-8726-4031-9b13-465b781352ed} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/764/764b68fe-a6f6-4b5d-ae50-c17628a53bc9/-2_0_57_1_122/ in table test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9) located on disk default of type local, from mark 0 with max_rows_to_read = 22304): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33300) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a954baa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:14:31.075422 [ 29577 ] {793acb4e-8726-4031-9b13-465b781352ed} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/764/764b68fe-a6f6-4b5d-ae50-c17628a53bc9/-2_0_57_1_122/ in table test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9) located on disk default of type local, from mark 0 with max_rows_to_read = 22304): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a954baa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:14:31.356624 [ 2952 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:31.653833 [ 2695 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:31.738371 [ 2815 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:31.955419 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:32.024188 [ 2782 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:32.357928 [ 2771 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:32.654844 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:32.739404 [ 3058 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:32.744721 [ 29577 ] {7f2b7769-3da4-4e0c-9111-649bc220cb39} 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.10057.altinitytest (altinity build)) (from [::1]:35178) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:32.745951 [ 29577 ] {7f2b7769-3da4-4e0c-9111-649bc220cb39} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:32.790187 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:33.025246 [ 2766 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:33.359027 [ 2979 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:33.645818 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:33.655688 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:33.740506 [ 2891 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:34.026214 [ 2764 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:34.197343 [ 29577 ] {53f41675-73fb-4b44-ad36-32c20df03c07} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35242) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:34.198790 [ 29577 ] {53f41675-73fb-4b44-ad36-32c20df03c07} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:34.359813 [ 3029 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:34.493713 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:34.656564 [ 2858 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:34.741620 [ 2689 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:35.027248 [ 3035 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:35.335717 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:35.361078 [ 2840 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:35.657307 [ 2903 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:35.742900 [ 3086 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:36.028122 [ 2730 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:36.082151 [ 29577 ] {cf9231ef-09ae-4107-8312-0b7b4a9ac310} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35306) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:36.083586 [ 29577 ] {cf9231ef-09ae-4107-8312-0b7b4a9ac310} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:36.166036 [ 30980 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:36.362145 [ 3190 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:36.658232 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:36.743786 [ 2830 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:37.003755 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:37.029122 [ 2863 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:37.363193 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:37.624962 [ 29577 ] {84ecc2f0-c9ad-4d18-8694-b08c9adf798b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35354) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:37.626144 [ 29577 ] {84ecc2f0-c9ad-4d18-8694-b08c9adf798b} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:37.659194 [ 2726 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:37.744563 [ 3162 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:37.839734 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:38.030098 [ 3104 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:38.365416 [ 3161 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:38.660084 [ 2978 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:38.667529 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:38.745551 [ 2764 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.031544 [ 3126 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.238015 [ 17241 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.243359 [ 3029 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.243613 [ 2811 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.244236 [ 3074 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.244690 [ 3066 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.244954 [ 2744 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.245772 [ 3122 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.246096 [ 2825 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.246712 [ 3089 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.247059 [ 2930 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.247643 [ 2966 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.248425 [ 2729 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.248891 [ 3097 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.249769 [ 2827 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.251868 [ 2785 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.252337 [ 3139 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.252674 [ 2964 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.252960 [ 2861 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.253323 [ 2901 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.253532 [ 2994 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.253889 [ 3081 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.254843 [ 2834 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.255174 [ 2690 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.255689 [ 3112 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:39.256628 [ 2836 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.256652 [ 2823 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.257000 [ 2758 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.257081 [ 2864 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.257005 [ 2876 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.258035 [ 29577 ] {754b88ce-4a25-4227-8401-c8c0e9ad7d27} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35414) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:39.260176 [ 2801 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.260184 [ 2936 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.260324 [ 29577 ] {754b88ce-4a25-4227-8401-c8c0e9ad7d27} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:39.366326 [ 2850 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.525791 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:39.660781 [ 3149 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:39.746196 [ 3169 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:40.032526 [ 2737 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:40.367158 [ 2945 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:40.368794 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:40.661657 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:40.708689 [ 4083 ] {38988765-41e7-4dce-9b7d-a9daeb523ddc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35486) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:40.709767 [ 4083 ] {38988765-41e7-4dce-9b7d-a9daeb523ddc} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:40.747234 [ 2976 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:41.033395 [ 2927 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:41.228064 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:41.367995 [ 2865 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:41.663252 [ 3189 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:41.748099 [ 2714 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:42.034383 [ 2860 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:42.068844 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:42.155641 [ 31184 ] {e06e8c2b-979c-4176-9e3f-247b2800d0a6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43556) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:42.157298 [ 31184 ] {e06e8c2b-979c-4176-9e3f-247b2800d0a6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:42.240519 [ 30753 ] {209e74ff-e23b-457b-b36a-05e72a7239b9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=784). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43572) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: SELECT is_done as is_running FROM system.mutations WHERE database==currentDatabase() AND table=='t1'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:42.241389 [ 30753 ] {209e74ff-e23b-457b-b36a-05e72a7239b9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=784). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:42.368737 [ 2905 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:42.664224 [ 2938 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:42.748875 [ 3135 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:42.924243 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:43.035672 [ 2701 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:43.369597 [ 2858 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:43.665395 [ 2912 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:43.719628 [ 4083 ] {92cd0b31-9e5e-43f4-bc0b-0f14950b05a7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43612) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:43.721549 [ 4083 ] {92cd0b31-9e5e-43f4-bc0b-0f14950b05a7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:43.749679 [ 2704 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:43.784682 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:44.036508 [ 3050 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:44.370316 [ 2934 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:44.626626 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:44.666270 [ 2786 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:44.751095 [ 2947 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:45.037274 [ 2873 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:45.209427 [ 31184 ] {2c7cddb8-3caa-488d-b207-4d5315a46ea7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43664) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:45.210715 [ 31184 ] {2c7cddb8-3caa-488d-b207-4d5315a46ea7} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:45.398428 [ 2879 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:45.478329 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:45.666894 [ 3088 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:45.752092 [ 3197 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:46.038147 [ 2974 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:46.329743 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:46.399460 [ 3171 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:46.668090 [ 2953 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:46.714712 [ 4083 ] {8906fb42-31cc-4120-bc92-fb67767f9265} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43702) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:46.716702 [ 4083 ] {8906fb42-31cc-4120-bc92-fb67767f9265} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:46.752995 [ 3130 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:47.039093 [ 2702 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:47.165182 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:47.400381 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:47.668972 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:47.753745 [ 2812 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:48.039844 [ 2710 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:48.044050 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:48.066199 [ 3271 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_162_167_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:48.401187 [ 2896 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:48.669679 [ 2747 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:48.754436 [ 3139 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:49.006065 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:49.041637 [ 3180 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:49.248944 [ 4083 ] {4d1f31a3-797b-433e-94ae-0690703a48db} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:43734) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:49.249986 [ 4083 ] {4d1f31a3-797b-433e-94ae-0690703a48db} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:49.401899 [ 2909 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:49.670643 [ 2903 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:49.755325 [ 2797 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:49.858707 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:50.042709 [ 2688 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:50.403235 [ 2989 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:50.671442 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:50.705165 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:50.756601 [ 2783 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:51.043591 [ 3002 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:51.273234 [ 31184 ] {e1d4e622-eb3c-4384-bd07-a75b48063ae2} 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.10057.altinitytest (altinity build)) (from [::1]:43788) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:51.274410 [ 31184 ] {e1d4e622-eb3c-4384-bd07-a75b48063ae2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:51.404092 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:51.540344 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:51.672433 [ 2833 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:51.757811 [ 3092 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:52.044726 [ 2698 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:52.129431 [ 3270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_162_167_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:52.373568 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:52.405044 [ 2990 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:52.673232 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:52.759047 [ 2804 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.045746 [ 2932 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.075606 [ 31184 ] {c668e0f1-acd6-455e-9cb6-6fcf7aeeaa4d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53952) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:53.076651 [ 31184 ] {c668e0f1-acd6-455e-9cb6-6fcf7aeeaa4d} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:53.177884 [ 31269 ] {2865afba-60bf-4be9-bf3f-72d28f33336d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53970) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:53.179159 [ 31269 ] {2865afba-60bf-4be9-bf3f-72d28f33336d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:53.206255 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:53.405933 [ 3066 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.673986 [ 2922 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.759925 [ 2906 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.950600 [ 2994 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.951152 [ 2878 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.951374 [ 2690 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.951595 [ 2900 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.951901 [ 2779 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.951915 [ 3089 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.952149 [ 2920 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.952534 [ 2837 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.952751 [ 2824 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.952842 [ 2797 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.953201 [ 3050 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.953568 [ 3103 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.953867 [ 2806 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.954041 [ 2924 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.954288 [ 2689 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.954353 [ 3064 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.955094 [ 2734 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.955613 [ 2745 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.955906 [ 3123 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.956378 [ 2825 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.956488 [ 2801 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.956932 [ 3109 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.957236 [ 3142 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:53.958644 [ 2704 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.958764 [ 2769 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.958765 [ 2923 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.958752 [ 2853 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.958899 [ 3157 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.959211 [ 2843 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.959236 [ 2694 ] {} test_9.alter_table_9 (d5c3c149-fa7e-4536-98d4-499e10c276c8): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:53.962100 [ 2853 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:54.007146 [ 2791 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:54.033086 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:54.046586 [ 2785 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:54.227006 [ 2838 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:54.406851 [ 2845 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:54.675026 [ 3013 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:54.760815 [ 3080 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:54.864390 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:55.047397 [ 3053 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:55.066828 [ 30753 ] {9c163d03-6f77-48e8-b7cf-481fefb977bd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53994) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:55.068262 [ 30753 ] {9c163d03-6f77-48e8-b7cf-481fefb977bd} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:55.407740 [ 2719 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:55.675808 [ 2803 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:55.732752 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:55.761587 [ 2846 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:56.048102 [ 2787 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:56.408540 [ 2715 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:56.563462 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:56.676598 [ 2823 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:56.716557 [ 30753 ] {b5697266-251d-4cc0-8c91-3d2d298de52e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54048) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:56.718143 [ 30753 ] {b5697266-251d-4cc0-8c91-3d2d298de52e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:56.762219 [ 3107 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.065066 [ 3076 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.408689 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:57.409579 [ 2844 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.677749 [ 2991 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.763009 [ 2849 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.882597 [ 17248 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.884175 [ 2752 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.884579 [ 3029 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.885092 [ 3085 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.885398 [ 2695 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.885727 [ 2837 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.886457 [ 2824 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.886764 [ 2761 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.887261 [ 2877 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.887679 [ 2689 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.889164 [ 2805 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.890745 [ 2725 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.890824 [ 2703 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.891105 [ 2977 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.891564 [ 2806 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.892038 [ 3016 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.892372 [ 2721 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.893084 [ 3158 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.893803 [ 2855 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.893850 [ 2825 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.894527 [ 2861 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.895055 [ 3122 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.896583 [ 3109 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.897453 [ 2786 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:14:57.898598 [ 3064 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.899039 [ 3019 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.899169 [ 2939 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.899188 [ 2690 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.899033 [ 2713 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.899450 [ 3118 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:57.899573 [ 2730 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.066249 [ 3097 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.206037 [ 31269 ] {689b81cf-5663-4e58-9f19-1a2c864be595} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54102) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:58.207319 [ 31269 ] {689b81cf-5663-4e58-9f19-1a2c864be595} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:58.233409 [ 2695 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/test_3/01715_background_checker_i20203/log. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/test_3/01715_background_checker_i20203/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.233493 [ 2837 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02922/test_9/table/log. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02922/test_9/table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:358: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001adce7bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019d82427 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.233824 [ 2695 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.233968 [ 2837 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.237753 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:58.240515 [ 2877 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest2/replicas/1/log_pointer. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest2/replicas/1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.240648 [ 2761 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/1/log_pointer. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.240692 [ 2725 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/replicas/2/log_pointer. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/replicas/2/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.240870 [ 2877 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.240873 [ 2689 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/replicas/2/log_pointer. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/replicas/2/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.241066 [ 2761 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.241009 [ 2977 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/2/log_pointer. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/2/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.241277 [ 2725 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.241554 [ 2689 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.241596 [ 2977 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.241770 [ 3016 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/source/replicas/1/log_pointer. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/source/replicas/1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.241840 [ 2806 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/replicas/1/log_pointer. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/replicas/1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.240873 [ 2721 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_9/rep_data/replicas/1/log_pointer. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/rep_data/replicas/1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.242152 [ 3016 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.242369 [ 2806 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.242526 [ 2721 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.247353 [ 3122 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bbed 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::load(std::shared_ptr) @ 0x0000000019d76f1f 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:181: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf864 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.248013 [ 3122 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.257512 [ 3085 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_15/data/log. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/data/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d8203f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019dcf8e4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.257940 [ 3085 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.272055 [ 3109 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Session expired (fault injected on send). 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::createLogEntriesToFetchBrokenParts() @ 0x0000000019d7a4d9 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:185: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf87d 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 17. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.272417 [ 3109 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.316469 [ 2861 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/replicas/1/parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/replicas/1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::createLogEntriesToFetchBrokenParts() @ 0x0000000019d7a4d9 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:185: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf87d 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.316511 [ 2855 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_15/data/replicas/data_r2/parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/data/replicas/data_r2/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::createLogEntriesToFetchBrokenParts() @ 0x0000000019d7a4d9 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:185: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf87d 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.316677 [ 2825 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest2/replicas/2/parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest2/replicas/2/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::createLogEntriesToFetchBrokenParts() @ 0x0000000019d7a4d9 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:185: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf87d 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.317026 [ 2861 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.317129 [ 2855 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.317311 [ 2825 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.344140 [ 2805 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeMergeStrategyPicker.cpp:128: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bf61 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::load(std::shared_ptr) @ 0x0000000019d76f1f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:181: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf864 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.344277 [ 2752 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeMergeStrategyPicker.cpp:128: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bf61 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::load(std::shared_ptr) @ 0x0000000019d76f1f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:181: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf864 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.344343 [ 2824 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeMergeStrategyPicker.cpp:128: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bf61 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::load(std::shared_ptr) @ 0x0000000019d76f1f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:181: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf864 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.344286 [ 3029 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeMergeStrategyPicker.cpp:128: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bf61 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::load(std::shared_ptr) @ 0x0000000019d76f1f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:181: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf864 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.344502 [ 2805 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.344272 [ 3158 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeMergeStrategyPicker.cpp:128: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bf61 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::load(std::shared_ptr) @ 0x0000000019d76f1f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:181: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf864 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.344216 [ 2786 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2/is_active. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeMergeStrategyPicker.cpp:128: DB::ReplicatedMergeTreeMergeStrategyPicker::refreshState() @ 0x0000000019d5bf61 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::load(std::shared_ptr) @ 0x0000000019d76f1f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:181: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf864 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.344788 [ 2752 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.345048 [ 2824 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.345144 [ 2786 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.345314 [ 3158 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.345309 [ 2815 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.410872 [ 3138 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.472773 [ 2703 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Session expired. 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::load(std::shared_ptr) @ 0x0000000019d75c2a 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:181: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf864 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.473369 [ 2703 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:14:58.678771 [ 2811 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:58.763941 [ 2966 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:59.067526 [ 2916 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:59.079827 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:59.411847 [ 3094 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:59.679484 [ 2777 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:59.764686 [ 3189 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:14:59.831619 [ 31269 ] {927822d7-5d79-4931-9367-73b6b572d8c4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54136) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:59.833162 [ 31269 ] {927822d7-5d79-4931-9367-73b6b572d8c4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:14:59.916992 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:00.068593 [ 3095 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:00.412665 [ 2909 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:00.680325 [ 2687 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:00.755462 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:00.765381 [ 2906 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:01.069514 [ 2751 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:01.391208 [ 31269 ] {7cc3e918-18c1-4aef-ab46-61536a5205c1} 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.10057.altinitytest (altinity build)) (from [::1]:54198) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:01.392437 [ 31269 ] {7cc3e918-18c1-4aef-ab46-61536a5205c1} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:01.413548 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:01.645452 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:01.681192 [ 3186 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:01.766231 [ 2977 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:02.070295 [ 2712 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:02.414302 [ 2974 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:02.476357 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:02.681977 [ 2824 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:02.775536 [ 2842 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:02.851336 [ 31269 ] {215b2d32-a1c8-4c01-ad62-7e4301f06142} 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.10057.altinitytest (altinity build)) (from [::1]:54926) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:02.852400 [ 31269 ] {215b2d32-a1c8-4c01-ad62-7e4301f06142} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:03.070949 [ 2752 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:03.323542 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:03.415142 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:03.497256 [ 31269 ] {412bce84-e873-4102-881f-f8566370c50c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54952) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: SELECT is_done as is_running FROM system.mutations WHERE database==currentDatabase() AND table=='t1'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:03.498385 [ 31269 ] {412bce84-e873-4102-881f-f8566370c50c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:03.730288 [ 2940 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:03.776396 [ 2915 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:04.071865 [ 3082 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:04.149758 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:04.415340 [ 31269 ] {b93265d2-d6f1-4257-8ff4-92d9b1896fc6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54978) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:04.415850 [ 3025 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:04.417011 [ 31269 ] {b93265d2-d6f1-4257-8ff4-92d9b1896fc6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:04.731081 [ 3062 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:04.777254 [ 2683 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:04.977709 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:05.151444 [ 2692 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:05.416954 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:05.732473 [ 2936 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:05.778880 [ 2687 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:05.935999 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:06.153508 [ 3022 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:06.418871 [ 3156 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:06.719459 [ 31269 ] {9953db7f-1f21-43ee-bc7d-432360a53703} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/a99/a991c6ec-26b8-4e79-9287-7cf7432a7148/7_0_123_2/ in table test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148) located on disk default of type local, from mark 2 with max_rows_to_read = 26820): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55018) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:15:06.733474 [ 3123 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:06.758109 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:06.762224 [ 31269 ] {9953db7f-1f21-43ee-bc7d-432360a53703} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column f): (while reading from part /var/lib/clickhouse/store/a99/a991c6ec-26b8-4e79-9287-7cf7432a7148/7_0_123_2/ in table test_9.alter_table_5 (a991c6ec-26b8-4e79-9287-7cf7432a7148) located on disk default of type local, from mark 2 with max_rows_to_read = 26820): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016257dc6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000016257985 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625617e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000162494cf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x0000000016249b7a 12. DB::ReadBuffer::next() @ 0x0000000007b3417b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b66ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d5afb2 15. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be84ef 16. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000019be8cde 17. DB::ReadBuffer::next() @ 0x0000000007b3417b 18. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000876ab42 19. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fd8d9e 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::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 @ 0x0000000016fccd45 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bbf248 22. ./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>>&) @ 0x0000000019be070e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 31. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 2025.06.12 19:15:06.780030 [ 2799 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:07.154803 [ 3138 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:07.419772 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:07.594930 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:07.734326 [ 3197 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:07.780943 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:08.155966 [ 3037 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:08.379123 [ 29516 ] {e5323c76-76bf-46b0-9276-0ce037c5fab5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55100) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:08.380374 [ 29516 ] {e5323c76-76bf-46b0-9276-0ce037c5fab5} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:08.420575 [ 3021 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:08.437435 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:08.782680 [ 2870 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:08.793277 [ 2882 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:09.156977 [ 3100 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:09.282275 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:09.421345 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:09.783980 [ 3076 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:09.794084 [ 2880 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:09.847330 [ 29516 ] {63b23f51-6895-44dc-aa69-8a88440fc6fe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55146) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:09.848894 [ 29516 ] {63b23f51-6895-44dc-aa69-8a88440fc6fe} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:10.119683 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:10.157786 [ 2694 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:10.422078 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:10.784778 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:10.794993 [ 2897 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.028865 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:11.220918 [ 3173 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.402789 [ 29580 ] {070cbb14-12d2-4d2a-9dbd-4ded86751ced} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55216) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:11.404334 [ 29580 ] {070cbb14-12d2-4d2a-9dbd-4ded86751ced} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:11.422990 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.430957 [ 2887 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.431112 [ 3067 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.431299 [ 3047 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.431465 [ 3077 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.431584 [ 2720 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.432073 [ 2916 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.432252 [ 2707 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.432479 [ 2926 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.432617 [ 2950 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.432952 [ 2712 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.433191 [ 2746 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.433341 [ 3059 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.433472 [ 2861 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.433759 [ 2698 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.434067 [ 3159 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.434367 [ 3183 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.434587 [ 3058 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.435223 [ 3080 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.435443 [ 2859 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.435551 [ 2802 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.436056 [ 2885 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.436445 [ 2963 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.436643 [ 2921 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:11.437753 [ 2886 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.437815 [ 3088 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.437853 [ 3002 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.437874 [ 3016 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.438010 [ 3185 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.438061 [ 2735 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.438112 [ 3085 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.438251 [ 2855 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.438852 [ 2749 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.438918 [ 3089 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.438975 [ 2776 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.785497 [ 2951 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.795777 [ 3034 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:11.883109 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:12.221703 [ 3106 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:12.423765 [ 2704 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:12.762910 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:12.786248 [ 2902 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:12.796461 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:13.275507 [ 2826 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:13.366104 [ 29580 ] {35d78433-096c-4408-ad88-fee7dab39589} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58806) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:13.367246 [ 29580 ] {35d78433-096c-4408-ad88-fee7dab39589} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:13.424504 [ 2829 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:13.617533 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:13.787538 [ 2724 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:13.797297 [ 2957 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:14.278320 [ 2725 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:14.426089 [ 2877 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:14.469293 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:14.788850 [ 3016 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:14.798240 [ 2754 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:14.882105 [ 29580 ] {ac064d8e-c130-449b-b560-4fe317d162fb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58882) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:14.883976 [ 29580 ] {ac064d8e-c130-449b-b560-4fe317d162fb} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:15.279506 [ 2720 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:15.307587 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:15.427329 [ 2737 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:15.790115 [ 2746 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:15.799114 [ 2762 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:16.138984 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:16.280241 [ 2904 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:16.417482 [ 29577 ] {c867898a-e047-46ae-8359-1c53c92789cd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58926) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:16.419178 [ 29577 ] {c867898a-e047-46ae-8359-1c53c92789cd} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:16.428322 [ 2913 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:16.791234 [ 2781 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:16.799813 [ 2753 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:16.976809 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:17.280955 [ 2962 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:17.429249 [ 3025 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:17.792086 [ 2803 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:17.800563 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:17.832010 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:17.882056 [ 4083 ] {2fcdb038-488e-433d-a94b-1b0dd2e7c2e6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:58962) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:17.883325 [ 4083 ] {2fcdb038-488e-433d-a94b-1b0dd2e7c2e6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:18.282845 [ 2988 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:18.430149 [ 2794 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:18.693862 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:18.792873 [ 3127 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:18.801234 [ 2925 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:19.284333 [ 2853 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:19.431205 [ 2688 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:19.551348 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:19.564689 [ 29577 ] {ba99be63-b300-45e8-b82b-673a5026b366} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59020) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:19.565912 [ 29577 ] {ba99be63-b300-45e8-b82b-673a5026b366} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:19.793690 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:19.802182 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:20.285316 [ 2725 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:20.395433 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:20.431953 [ 3072 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:20.794340 [ 3016 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:20.803221 [ 2825 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:21.234188 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:21.286260 [ 3188 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:21.432729 [ 2815 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:21.540631 [ 29580 ] {418ec947-8369-49b2-89ed-110b109b0093} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:59082) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:21.542391 [ 29580 ] {418ec947-8369-49b2-89ed-110b109b0093} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:21.795041 [ 3179 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:21.804157 [ 3100 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:22.088414 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:22.407481 [ 2932 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:22.433392 [ 3034 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:22.795631 [ 3076 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:22.805113 [ 2691 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:22.915371 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:23.060136 [ 29580 ] {0490ed65-a480-4649-b176-4b9c22ea0fd9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53124) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:23.061182 [ 29580 ] {0490ed65-a480-4649-b176-4b9c22ea0fd9} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:23.408173 [ 2759 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.434377 [ 2826 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.761938 [ 17163 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.762808 [ 2966 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.762862 [ 2724 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.763017 [ 3073 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.763284 [ 2892 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.763463 [ 3079 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.764761 [ 2807 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.764967 [ 3075 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.764991 [ 2957 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.765165 [ 3039 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.765361 [ 2770 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.765695 [ 2837 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.765941 [ 2838 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.766165 [ 2834 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.766406 [ 2695 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.766670 [ 3086 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.766885 [ 2819 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.767109 [ 3193 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.767353 [ 2800 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.767555 [ 3055 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.767786 [ 2862 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.767966 [ 2830 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.768260 [ 2851 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.768554 [ 3190 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.768828 [ 3134 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:23.769683 [ 2947 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.769686 [ 3138 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.769778 [ 2693 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.769784 [ 3196 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.769879 [ 2725 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.769883 [ 3029 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.770179 [ 3004 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.796274 [ 3124 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.805857 [ 3186 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.818206 [ 2690 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:23.861045 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:24.409828 [ 2860 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:24.435277 [ 3115 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:24.694866 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:24.796944 [ 3023 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:24.825142 [ 3071 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:25.078018 [ 29580 ] {3613dfd2-2035-40f1-8ad9-b39c8b81ff7a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53170) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:25.079568 [ 29580 ] {3613dfd2-2035-40f1-8ad9-b39c8b81ff7a} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:25.410789 [ 3076 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:25.436029 [ 2691 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:25.520845 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:25.797729 [ 2744 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:25.825773 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:26.379123 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:26.411721 [ 3180 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:26.436905 [ 2768 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:26.559078 [ 29580 ] {0660e65f-e5fe-430f-9201-6e1ffbc89e93} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53234) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:26.560119 [ 29580 ] {0660e65f-e5fe-430f-9201-6e1ffbc89e93} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:26.798701 [ 2923 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:26.827078 [ 2717 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:27.250875 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:27.412621 [ 2731 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:27.437655 [ 2685 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:27.799611 [ 3184 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:27.828187 [ 3075 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:28.089415 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:28.413474 [ 3039 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:28.439156 [ 3173 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:28.576284 [ 29580 ] {6e65ebc6-db11-4678-8b20-3cf9dc43ceb6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53302) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:28.578220 [ 29580 ] {6e65ebc6-db11-4678-8b20-3cf9dc43ceb6} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:28.800701 [ 3140 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:28.829237 [ 3063 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:28.930871 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:29.414337 [ 3098 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:29.440433 [ 3077 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:29.765333 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:29.801642 [ 2861 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:29.829997 [ 2787 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:30.042333 [ 29580 ] {85f25c4d-a7b7-4693-87a9-7409a9c19240} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53388) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:30.043375 [ 29580 ] {85f25c4d-a7b7-4693-87a9-7409a9c19240} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:30.415321 [ 2872 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:30.441653 [ 2871 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:30.605336 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:30.802366 [ 2893 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:30.831016 [ 2898 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:31.416131 [ 3126 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:31.442410 [ 2883 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:31.446290 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:31.566339 [ 29577 ] {f3a31f27-2e7b-4b53-b218-2ff0609c92d4} 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.10057.altinitytest (altinity build)) (from [::1]:53418) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:31.567535 [ 29577 ] {f3a31f27-2e7b-4b53-b218-2ff0609c92d4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:31.803042 [ 2704 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:31.831747 [ 2907 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:32.280039 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:32.416847 [ 3029 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:32.443352 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:32.794989 [ 29580 ] {549f1f1c-292f-4329-91f0-4755b2a14ec4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53104) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:32.795788 [ 29580 ] {549f1f1c-292f-4329-91f0-4755b2a14ec4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:32.803670 [ 2765 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:32.832428 [ 2796 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:33.081473 [ 29580 ] {26b65295-9f1a-4b40-94f4-b80c39d91f9f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53112) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:33.082606 [ 29580 ] {26b65295-9f1a-4b40-94f4-b80c39d91f9f} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:33.146110 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:33.418265 [ 3122 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:33.444094 [ 2944 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:33.804395 [ 3158 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:33.833159 [ 2976 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:34.016638 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:34.419070 [ 3100 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:34.445064 [ 2757 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:34.631641 [ 29577 ] {d75c223b-48b3-4696-b0a3-831d491623d1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53174) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:34.632910 [ 29577 ] {d75c223b-48b3-4696-b0a3-831d491623d1} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:34.805263 [ 2773 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:34.834667 [ 2812 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:34.851973 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:35.419940 [ 3164 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:35.445939 [ 2694 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:35.718922 [ 29580 ] {243660c2-9892-4afb-bc76-f6b0a5d14c92} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53196) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:35.720473 [ 29580 ] {243660c2-9892-4afb-bc76-f6b0a5d14c92} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:35.763939 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:35.806207 [ 2849 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:35.835477 [ 2991 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:36.092928 [ 29580 ] {fdbd11ce-577c-4b95-b423-fa0562253038} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53214) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:36.094200 [ 29580 ] {fdbd11ce-577c-4b95-b423-fa0562253038} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:36.420825 [ 2811 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:36.446911 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:36.613468 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:36.807169 [ 2819 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:36.836396 [ 2682 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:37.421717 [ 3053 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:37.447684 [ 3140 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:37.492423 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:37.588501 [ 29580 ] {2116e904-2394-4261-b96b-259dacbeb6e2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53282) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:37.589637 [ 29580 ] {2116e904-2394-4261-b96b-259dacbeb6e2} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:37.808179 [ 3054 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:37.837307 [ 3080 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:38.320742 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:38.422624 [ 2963 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:38.448390 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:38.808941 [ 3188 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:38.838096 [ 2848 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:39.155113 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:39.423318 [ 2756 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:39.449175 [ 2733 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:39.694366 [ 29580 ] {cb176d96-308d-4875-9274-1dbc178702fb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53312) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:39.695737 [ 29580 ] {cb176d96-308d-4875-9274-1dbc178702fb} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:39.809560 [ 3099 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:39.839064 [ 2836 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:39.985290 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:40.424048 [ 3180 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:40.449837 [ 3164 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:40.810369 [ 2843 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:40.839861 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:40.908487 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:41.424797 [ 2954 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:41.450867 [ 2947 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:41.812908 [ 2765 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:41.824277 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:41.841023 [ 3079 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:41.857621 [ 29580 ] {4270ad55-f702-4b03-bb8f-0a44b736cbed} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53368) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:41.940536 [ 29580 ] {4270ad55-f702-4b03-bb8f-0a44b736cbed} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:42.426059 [ 2682 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.452120 [ 2767 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.666854 [ 29580 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:42.777026 [ 3187 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.777097 [ 2892 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.777341 [ 3089 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.777802 [ 3148 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.778165 [ 2955 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.779241 [ 3196 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.779681 [ 3085 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.780034 [ 2735 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.780426 [ 2771 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.781220 [ 3042 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.781611 [ 2859 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.781882 [ 3037 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.782194 [ 3000 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.782533 [ 3053 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.783512 [ 3140 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.783935 [ 3060 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.784059 [ 3125 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.784541 [ 2689 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.784840 [ 3171 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.785294 [ 2824 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.785735 [ 2928 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.786231 [ 3054 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.786674 [ 3080 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:42.787854 [ 2817 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.787928 [ 2868 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.787974 [ 2965 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.788004 [ 2784 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.788023 [ 2690 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.788134 [ 3039 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.791047 [ 2920 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.814296 [ 3108 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:42.842052 [ 2820 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:43.427036 [ 2932 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:43.453288 [ 3120 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:43.458352 [ 29577 ] {2c6154dc-a982-47ca-bc63-986131cea1db} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44936) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:43.459583 [ 29577 ] {2c6154dc-a982-47ca-bc63-986131cea1db} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:43.494985 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:43.815557 [ 2876 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:43.938285 [ 2958 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:44.390009 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:44.427757 [ 3116 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:44.454266 [ 3174 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:44.816552 [ 2829 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:44.939151 [ 3142 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:45.080005 [ 29577 ] {4dbf4947-0dde-4502-a3c1-7fcd3ca89b33} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:44988) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:45.081191 [ 29577 ] {4dbf4947-0dde-4502-a3c1-7fcd3ca89b33} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:45.240389 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:45.428548 [ 3004 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:45.455449 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:45.817306 [ 3185 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:45.939813 [ 3039 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:46.082395 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:46.429260 [ 2806 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:46.456207 [ 3086 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:46.818013 [ 2975 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:46.823270 [ 29577 ] {80e1ec82-e164-4fea-b14b-33f716384a01} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45048) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:46.824751 [ 29577 ] {80e1ec82-e164-4fea-b14b-33f716384a01} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:46.940519 [ 3077 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:46.985805 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:47.430136 [ 3042 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:47.457027 [ 3179 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:47.815956 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:47.818831 [ 2992 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:47.941419 [ 3045 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:48.291865 [ 29577 ] {56e14443-0dcf-4ceb-8136-c468e97f812e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45108) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:48.292858 [ 29577 ] {56e14443-0dcf-4ceb-8136-c468e97f812e} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:48.430968 [ 2748 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:48.457955 [ 2744 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:48.654039 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:48.819529 [ 2930 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:48.942165 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:49.431777 [ 2693 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:49.459465 [ 2939 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:49.490284 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:49.820265 [ 2745 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:49.943215 [ 3111 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:50.026050 [ 29577 ] {41d3712f-ba1d-43fd-b68a-4087fe4719c4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45150) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:50.027160 [ 29577 ] {41d3712f-ba1d-43fd-b68a-4087fe4719c4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:50.367647 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:50.433915 [ 3160 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:50.461009 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:50.821297 [ 2994 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:50.944307 [ 3079 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:51.223503 [ 29577 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:51.435160 [ 3003 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:51.462069 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:51.556724 [ 29577 ] {a36fa57b-be04-48d3-92b3-433a9b60e8f4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:45214) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:51.558258 [ 29577 ] {a36fa57b-be04-48d3-92b3-433a9b60e8f4} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:51.822623 [ 2945 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:51.945296 [ 3188 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:52.063699 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:52.436320 [ 2857 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:52.463039 [ 2860 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:52.891501 [ 2804 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:52.910264 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:52.946177 [ 2789 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.188012 [ 17246 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.189063 [ 2803 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.189217 [ 2972 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.189411 [ 2898 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.189864 [ 2914 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.190125 [ 3052 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.190213 [ 2872 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.190620 [ 3025 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.191459 [ 3095 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.192120 [ 3176 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.192172 [ 2756 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.192300 [ 2866 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.192716 [ 2712 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.192950 [ 2733 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.193100 [ 3175 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.193229 [ 3059 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.193356 [ 3183 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.193817 [ 2935 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.193967 [ 2889 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.193967 [ 3066 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.194627 [ 3058 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.194965 [ 2836 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.195184 [ 2715 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.195208 [ 2777 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.195693 [ 3099 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.196182 [ 2793 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:15:53.197495 [ 3120 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.197521 [ 3153 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.197581 [ 3071 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.198143 [ 2764 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.198541 [ 2788 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.198623 [ 2995 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.198465 [ 3114 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.199948 [ 2764 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.239117 [ 4083 ] {614b492f-ab7c-44fa-a36d-865b81912ebc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33820) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:53.240049 [ 4083 ] {614b492f-ab7c-44fa-a36d-865b81912ebc} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:53.437274 [ 2934 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.463884 [ 3160 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.771925 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:53.892500 [ 2820 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:53.947084 [ 2868 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:54.438081 [ 2946 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:54.464814 [ 2846 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:54.604235 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:54.893276 [ 3013 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:54.948085 [ 2750 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:55.048926 [ 4083 ] {79db034b-b971-4b0a-a244-74d4d86d19f7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33866) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:55.051025 [ 4083 ] {79db034b-b971-4b0a-a244-74d4d86d19f7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:55.433704 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:55.438950 [ 3104 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:55.465608 [ 2928 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:55.893928 [ 2996 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:55.949055 [ 3121 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:56.272198 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:56.439714 [ 3189 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:56.466663 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:56.894959 [ 2691 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:56.950007 [ 3102 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:56.999157 [ 4083 ] {a0fe13ee-5eba-4d0d-bff2-2968aaddcfe3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33932) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:57.000234 [ 4083 ] {a0fe13ee-5eba-4d0d-bff2-2968aaddcfe3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:57.112919 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:57.440425 [ 3176 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:57.467355 [ 2930 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:57.895640 [ 2747 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:57.945451 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:58.079351 [ 3012 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:58.441643 [ 3142 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:58.468616 [ 2941 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:58.561442 [ 4083 ] {ed802e06-4ac8-4477-912b-0762ff069fac} 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.10057.altinitytest (altinity build)) (from [::1]:33996) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:58.563687 [ 4083 ] {ed802e06-4ac8-4477-912b-0762ff069fac} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:58.583900 [ 31184 ] {ffe8f947-1b24-4338-9321-4aec87f653ea} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34010) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:58.588496 [ 31184 ] {ffe8f947-1b24-4338-9321-4aec87f653ea} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:58.782674 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:58.896513 [ 3103 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:59.081201 [ 3156 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:59.442616 [ 2987 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:59.472320 [ 2863 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:15:59.629150 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:15:59.897505 [ 2807 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:00.082445 [ 2797 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:00.138353 [ 4083 ] {69368dec-68ab-4233-9a87-91dff190bdc5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34058) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'alter_table_') 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:00.199317 [ 4083 ] {69368dec-68ab-4233-9a87-91dff190bdc5} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:00.443554 [ 2928 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:00.473081 [ 3049 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:00.500802 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:00.899583 [ 2893 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:01.083736 [ 2736 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:01.341673 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:01.444382 [ 2686 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:01.473846 [ 2789 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:01.900807 [ 3135 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:02.084803 [ 2932 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:02.290013 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:02.445201 [ 2683 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:02.474850 [ 2864 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:02.901404 [ 2930 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:03.085950 [ 2854 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:03.163282 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:03.446118 [ 2696 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:03.475729 [ 2858 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:03.901988 [ 2706 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:04.006764 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:04.086912 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:04.447030 [ 3181 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:04.476394 [ 2697 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:04.846170 [ 4083 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:04.902817 [ 2802 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.087821 [ 3092 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.274636 [ 17206 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.275894 [ 3088 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.276190 [ 2771 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.277001 [ 3158 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.277493 [ 3009 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.277727 [ 3083 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.278978 [ 2926 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.279340 [ 2842 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.279482 [ 2861 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.279651 [ 3053 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.280297 [ 2946 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.280808 [ 2846 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.281617 [ 3188 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.282144 [ 2797 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.282955 [ 2689 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.283321 [ 2963 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.283809 [ 3159 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.284361 [ 2913 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.285626 [ 2945 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.285555 [ 3021 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.288655 [ 3014 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.289053 [ 2837 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.289673 [ 2847 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.290099 [ 2834 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:05.291079 [ 2776 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.291460 [ 3080 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.291645 [ 2815 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.291831 [ 2807 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.291856 [ 3072 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.291862 [ 3068 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.293031 [ 2776 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.294297 [ 3063 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.424069 [ 2806 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.447779 [ 3028 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.477176 [ 2848 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:05.697652 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:05.903530 [ 2832 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:06.088722 [ 3059 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:06.139954 [ 30753 ] {93058f87-2c47-4b66-8803-ae463f7ea8f5} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54068) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: ALTER TABLE alter_table_1 MODIFY SETTING max_replicated_merges_in_queue=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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001940010d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c207bf 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:06.141011 [ 30753 ] {93058f87-2c47-4b66-8803-ae463f7ea8f5} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001940010d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c207bf 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c1dfe3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:06.240937 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {751051e6-adca-4665-9806-ed7c89ce0982::202506_1_176_70}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:06.448536 [ 3113 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:06.477963 [ 3095 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:06.517152 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:06.904312 [ 3118 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:07.089446 [ 2941 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:07.373625 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:07.449289 [ 3168 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:07.478781 [ 3186 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:07.905118 [ 3194 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:08.090301 [ 3156 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:08.220562 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:08.450088 [ 2780 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:08.479473 [ 2830 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:08.906051 [ 2801 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:09.078993 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:09.091402 [ 3093 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:09.450986 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:09.480147 [ 3128 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:09.907207 [ 2753 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:09.917986 [ 42554 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:10.092185 [ 3080 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:10.452104 [ 3063 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:10.537685 [ 2869 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:10.754821 [ 42566 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:10.908089 [ 3131 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:11.093042 [ 2890 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:11.453053 [ 3169 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:11.539148 [ 3040 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:11.583554 [ 42566 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:11.909021 [ 2847 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:12.093934 [ 3038 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:12.410060 [ 42554 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:12.454053 [ 2911 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:12.540150 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:12.909798 [ 2752 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:13.095055 [ 2865 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:13.240362 [ 42554 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:13.455096 [ 2856 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:13.541006 [ 3021 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:13.910859 [ 3148 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:14.096241 [ 2891 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:14.099617 [ 42554 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:14.455954 [ 2703 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:14.541820 [ 2702 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:14.911678 [ 3178 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:14.925059 [ 42554 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:15.097357 [ 3013 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:15.456832 [ 2916 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:15.542660 [ 2804 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:15.757628 [ 42554 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:15.912609 [ 3010 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:16.098151 [ 2914 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:16.457671 [ 3005 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:16.543426 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:16.600414 [ 42566 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:16.913457 [ 2876 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:17.178095 [ 2935 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:17.435763 [ 42566 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:17.458354 [ 2958 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:17.544480 [ 2995 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:17.914309 [ 2880 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.180139 [ 2883 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.269003 [ 42566 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:18.459251 [ 2851 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.545588 [ 3126 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.719499 [ 2886 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.719680 [ 2828 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.719984 [ 3075 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.720026 [ 2809 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.720320 [ 2863 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.722157 [ 3112 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.722292 [ 2886 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.722459 [ 2828 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.722506 [ 2909 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.722964 [ 2828 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.722914 [ 2936 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.723219 [ 2809 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.723378 [ 2832 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.723867 [ 3075 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.723985 [ 3183 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.724293 [ 2716 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.724333 [ 2863 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.724747 [ 2896 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.725431 [ 3133 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.726731 [ 2844 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.726825 [ 3107 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.727522 [ 2729 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.727945 [ 2836 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.729098 [ 2700 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.729376 [ 3059 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.729548 [ 3127 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.730226 [ 3182 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.730630 [ 2793 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.730703 [ 3101 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.756034 [ 2695 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.788806 [ 3106 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.789020 [ 2795 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.789433 [ 3192 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.789795 [ 3164 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:18.792347 [ 3174 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.792604 [ 2843 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.792755 [ 2997 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.792780 [ 2964 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.792962 [ 2720 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.794577 [ 2720 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:18.915304 [ 2998 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:19.088373 [ 31269 ] {46829169-85b1-4bd8-95c2-9f462538c915} executeQuery: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/log_pointer. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54192) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SYSTEM SYNC REPLICA alter_table_7 STRICT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.088665 [ 29580 ] {707c2bd0-5a85-40b7-ba00-c7699033b249} executeQuery: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/log_pointer. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54218) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SYSTEM SYNC REPLICA alter_table_1 STRICT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.088724 [ 29577 ] {442d07c3-c68b-4ac3-96fc-b7a26a113ed6} executeQuery: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/log_pointer. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54220) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SYSTEM SYNC REPLICA alter_table_9 STRICT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.088779 [ 42534 ] {cf9a5237-bd65-457a-9477-b51f1e3478ee} executeQuery: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/log_pointer. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54238) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SYSTEM SYNC REPLICA alter_table_0 STRICT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.088804 [ 4083 ] {12994f59-80f2-4ce3-ae76-479854cb5d80} executeQuery: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/log_pointer. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54236) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SYSTEM SYNC REPLICA alter_table_4 STRICT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.088682 [ 29516 ] {98dc2c2f-6bd5-4a0e-8d79-aacd9bacdb1e} executeQuery: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/log_pointer. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54196) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SYSTEM SYNC REPLICA alter_table_8 STRICT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.088725 [ 30980 ] {846e405f-d4fe-40fe-93ab-5487e877ad12} executeQuery: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/log_pointer. (KEEPER_EXCEPTION) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:54212) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SYSTEM SYNC REPLICA alter_table_5 STRICT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.090093 [ 31269 ] {46829169-85b1-4bd8-95c2-9f462538c915} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.090332 [ 29580 ] {707c2bd0-5a85-40b7-ba00-c7699033b249} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.090570 [ 42534 ] {cf9a5237-bd65-457a-9477-b51f1e3478ee} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.090686 [ 29577 ] {442d07c3-c68b-4ac3-96fc-b7a26a113ed6} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.091096 [ 4083 ] {12994f59-80f2-4ce3-ae76-479854cb5d80} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.091759 [ 29516 ] {98dc2c2f-6bd5-4a0e-8d79-aacd9bacdb1e} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.092155 [ 30980 ] {846e405f-d4fe-40fe-93ab-5487e877ad12} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001945d4f0 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1134: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000001826131d 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x00000000182555c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.138675 [ 31184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:19.181182 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:19.459945 [ 2954 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:19.546656 [ 2831 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:19.915992 [ 3072 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:19.975316 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:20.181869 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:20.376174 [ 30753 ] {a5ade685-160a-4dee-b227-640c271dfad0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56528) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (in query: SELECT if((countDistinct(data) as c) == 0, 1, c) FROM ( SELECT _table, (count(), sum(a), sum(b), round(sum(c))) AS data FROM merge(currentDatabase(), 'alter_table_') GROUP 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:20.377764 [ 30753 ] {a5ade685-160a-4dee-b227-640c271dfad0} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1b517 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019aeee2a 8. ./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) @ 0x000000001a934995 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a9330ef 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1432: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a932d90 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1911: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93d5fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 14. ./build_docker/./src/Storages/StorageMerge.cpp:1131: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000192d3bf5 15. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000192d2915 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e2c82 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90de19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dba0a9 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017db9d50 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:20.460710 [ 3130 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:20.547442 [ 2750 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:20.805774 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:20.916713 [ 2881 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:21.182899 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:21.461364 [ 3053 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:21.548319 [ 3136 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:21.622813 [ 30753 ] {27f4b683-fb57-4c88-b5fb-d3d6bf4215b4} executeQuery: Code: 57. DB::Exception: Table test_9.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56584) (comment: 03215_key_condition_bug.sql) (in query: CREATE TABLE t (`x` Int8) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 58886, min_bytes_for_wide_part = 893536307, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 81, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 8438805, compact_parts_max_granules_to_buffer = 65, compact_parts_merge_max_bytes_to_prefetch_part = 18404187, merge_max_block_size = 22130, old_parts_lifetime = 349., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 42, min_merge_bytes_to_use_direct_io = 296555023, index_granularity_bytes = 28682433, concurrent_part_removal_threshold = 34, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 96169, primary_key_compress_block_size = 58664), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:21.623691 [ 30753 ] {27f4b683-fb57-4c88-b5fb-d3d6bf4215b4} TCPHandler: Code: 57. DB::Exception: Table test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:21.631464 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:21.917824 [ 2917 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:22.183655 [ 3022 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:22.456715 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:22.462033 [ 2886 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:22.549092 [ 2930 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:22.919200 [ 3012 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:23.184384 [ 3095 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:23.385344 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:23.462868 [ 2811 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:23.549945 [ 3175 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:23.919991 [ 2936 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:24.185065 [ 2993 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:24.234792 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:24.463579 [ 3098 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:24.550825 [ 3162 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:24.920651 [ 2890 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:25.075233 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:25.185779 [ 2734 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:25.510912 [ 2887 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:25.552308 [ 3152 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:25.906506 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:25.921621 [ 3153 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:26.187126 [ 3120 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:26.512519 [ 3057 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:26.553920 [ 3174 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:26.749757 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:26.922866 [ 2999 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:27.111731 [ 30753 ] {ad489589-b99f-4205-8d98-1807b310fa33} executeQuery: Code: 57. DB::Exception: Table test_9.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56984) (comment: 03151_external_cross_join.sql) (in query: CREATE TABLE t1 (x 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:27.112897 [ 30753 ] {ad489589-b99f-4205-8d98-1807b310fa33} TCPHandler: Code: 57. DB::Exception: Table test_9.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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c4ca60 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c440d9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cee 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:27.187973 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:27.513391 [ 2840 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:27.554903 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:27.606324 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:27.923656 [ 2897 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:28.188785 [ 3194 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:28.460384 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:28.514149 [ 3064 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:28.555772 [ 2943 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:28.924542 [ 2986 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:29.189442 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:29.296165 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:29.515339 [ 2881 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:29.556469 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:29.925355 [ 3053 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:30.128074 [ 29516 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:30.190105 [ 3052 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:30.516151 [ 3176 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:30.557146 [ 2769 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:30.926145 [ 3030 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:30.968428 [ 31269 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:31.190810 [ 2939 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:31.516880 [ 3132 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:31.557862 [ 3177 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:31.826347 [ 30753 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad89d20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168260f0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000168256a2 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016825a99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175adcc6 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175ae3bb 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a1f3957 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1e3cb1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d826f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:31.926790 [ 2909 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:32.191600 [ 2761 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:32.517888 [ 2852 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:32.559044 [ 3197 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:32.927600 [ 3093 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:33.192241 [ 2862 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:33.519092 [ 2792 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:33.559957 [ 2703 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:33.928465 [ 2932 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:34.192965 [ 2771 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:34.519854 [ 2930 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:34.560709 [ 2843 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:34.929377 [ 2774 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:35.193840 [ 2840 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:35.520669 [ 3113 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:35.556506 [ 30753 ] {005beaeb-78dd-4d2b-a6e9-4d010a8c7701} executeQuery: Code: 107. DB::Exception: Cannot open file /var/lib/clickhouse/store/c56/c56164b3-41d0-412e-b0af-1c8346846a14/all_0_1_1/n.bin: , errno: 2, strerror: No such file or directory: (while reading column n): (while reading from part /var/lib/clickhouse/store/c56/c56164b3-41d0-412e-b0af-1c8346846a14/all_0_1_1/ in table test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (FILE_DOESNT_EXIST) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55694) (comment: 02369_lost_part_intersecting_merges.sh) (in query: select * from rmt1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa7b505 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa7b1fd 5. ./build_docker/./src/IO/OpenedFile.cpp:0: DB::OpenedFile::getFD() const @ 0x0000000016248ba3 6. ./src/IO/ReadBufferFromFile.h:0: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x0000000016240200 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 @ 0x000000001623fa6b 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:0: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000001623f8fe 9. ./build_docker/./src/Disks/DiskLocal.cpp:334: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000001729e745 10. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:127: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000198818da 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:0: DB::MergeTreeReaderStream::init() @ 0x0000000019be33be 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:172: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000019be5062 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:315: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000019beeaa2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:401: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bef78b 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50a46 16. ./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) @ 0x0000000019beda4a 17. ./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>>&) @ 0x0000000019bed00e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:16:35.558073 [ 30753 ] {005beaeb-78dd-4d2b-a6e9-4d010a8c7701} TCPHandler: Code: 107. DB::Exception: Cannot open file /var/lib/clickhouse/store/c56/c56164b3-41d0-412e-b0af-1c8346846a14/all_0_1_1/n.bin: , errno: 2, strerror: No such file or directory: (while reading column n): (while reading from part /var/lib/clickhouse/store/c56/c56164b3-41d0-412e-b0af-1c8346846a14/all_0_1_1/ in table test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa7b505 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa7b1fd 5. ./build_docker/./src/IO/OpenedFile.cpp:0: DB::OpenedFile::getFD() const @ 0x0000000016248ba3 6. ./src/IO/ReadBufferFromFile.h:0: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x0000000016240200 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 @ 0x000000001623fa6b 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:0: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000001623f8fe 9. ./build_docker/./src/Disks/DiskLocal.cpp:334: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000001729e745 10. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:127: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000198818da 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:0: DB::MergeTreeReaderStream::init() @ 0x0000000019be33be 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:172: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000019be5062 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:315: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000019beeaa2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:401: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bef78b 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f50a46 16. ./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) @ 0x0000000019beda4a 17. ./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>>&) @ 0x0000000019bed00e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bcd090 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019bda589 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019bd7a28 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c079eb 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a979aaa 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c02592 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a9599b7 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2cdf8b 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f0d2a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e22a3 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e188c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 2025.06.12 19:16:35.561392 [ 2742 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:35.759661 [ 2901 ] {} test_9.rmt1 (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/c56/c56164b3-41d0-412e-b0af-1c8346846a14/all_0_1_1/columns.txt: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa7b505 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa7b1fd 5. ./build_docker/./src/IO/OpenedFile.cpp:0: DB::OpenedFile::getFD() const @ 0x0000000016248ba3 6. ./src/IO/ReadBufferFromFile.h:0: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x0000000016240200 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 @ 0x000000001623fa6b 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:0: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000001623f8fe 9. ./build_docker/./src/Disks/DiskLocal.cpp:334: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000001729e745 10. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:127: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000198818da 11. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:0: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x0000000019e2d0df 12. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:419: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x0000000019e2cbf4 13. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000019d690a6 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000019d6c107 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000019d6ed1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d6fa22 17. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:35.759929 [ 2901 ] {} test_9.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_0_1_1 looks broken. Removing it and will try to fetch. 2025.06.12 19:16:35.760068 [ 2901 ] {} test_9.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_0_1_1 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.06.12 19:16:35.762382 [ 2901 ] {} test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14): Detached 3 parts covered by broken part all_0_1_1: all_0_1_1, all_0_0_0, all_1_1_0 2025.06.12 19:16:35.787218 [ 6456 ] {} test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14): Directory /var/lib/clickhouse/store/c56/c56164b3-41d0-412e-b0af-1c8346846a14/all_0_1_1 (part to remove) doesn't exist or one of nested files has gone. Most likely this is due to manual removing. This should be discouraged. Ignoring. 2025.06.12 19:16:35.977919 [ 3019 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:36.195088 [ 2682 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:36.521782 [ 3183 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:36.562246 [ 2836 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:36.979437 [ 2965 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:37.196250 [ 2762 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:37.523414 [ 2890 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:37.563381 [ 2834 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:37.980139 [ 2956 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:38.197064 [ 3121 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:38.524672 [ 3069 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:38.564237 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:38.981043 [ 2744 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:39.197770 [ 2720 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:39.526153 [ 2939 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:39.565095 [ 2874 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:39.981716 [ 2991 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:40.198466 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:40.259716 [ 29516 ] {eb830238-0ef5-4de6-af2a-8d7999196462} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:55848) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:40.261117 [ 29516 ] {eb830238-0ef5-4de6-af2a-8d7999196462} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:40.627006 [ 2819 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:40.627207 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:40.982338 [ 3039 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:41.199192 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:41.628486 [ 2729 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:41.628576 [ 2899 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:41.983183 [ 2867 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:42.200138 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:42.629466 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:42.630083 [ 2792 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:42.984026 [ 2956 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:43.200934 [ 2895 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:43.630213 [ 3067 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:43.631113 [ 2743 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:43.984963 [ 2684 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:44.046914 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3655178d-96ea-42c6-867f-61b9ceac796e::202506_1_166_41}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:44.201783 [ 3144 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:44.650327 [ 2970 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:44.650324 [ 3095 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:44.986760 [ 2688 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:45.202650 [ 2826 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:45.739778 [ 3011 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:45.739824 [ 2845 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:45.987773 [ 2855 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:46.203605 [ 2737 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:46.740902 [ 2801 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:46.740925 [ 2806 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:46.988714 [ 2985 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:47.204478 [ 2719 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:47.741831 [ 2962 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:47.741875 [ 3047 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:47.989604 [ 3122 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:48.205375 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:48.742726 [ 2953 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:48.742796 [ 2864 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:48.990342 [ 3166 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:49.206123 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:49.743471 [ 2878 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:49.743496 [ 3118 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:49.991501 [ 2939 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:50.207265 [ 2811 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:50.744332 [ 2725 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:50.744976 [ 3073 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:50.767069 [ 31269 ] {0f750f47-3a55-455c-a57e-90d31fe32407} 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.10057.altinitytest (altinity build)) (from [::1]:49414) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:50.768031 [ 31269 ] {0f750f47-3a55-455c-a57e-90d31fe32407} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:50.992500 [ 3185 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:51.208094 [ 3112 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:51.745107 [ 3093 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:51.745644 [ 3093 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:51.993339 [ 3161 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:52.209001 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:52.745882 [ 3087 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:52.746252 [ 3141 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:52.994186 [ 2857 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:53.209885 [ 2966 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:53.747065 [ 3010 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:53.747221 [ 2724 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:53.995064 [ 3154 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:54.210910 [ 2695 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:54.747750 [ 2900 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:54.747898 [ 2981 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:54.995740 [ 2925 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:55.211758 [ 2741 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:55.478728 [ 31269 ] {bec4de43-d70b-4225-af9c-43f248cd9804} 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.10057.altinitytest (altinity build)) (from [::1]:51672) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:55.479768 [ 31269 ] {bec4de43-d70b-4225-af9c-43f248cd9804} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:16:55.748555 [ 2924 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:55.748593 [ 3150 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:55.996428 [ 2909 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:56.213801 [ 3029 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:56.750292 [ 3108 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:56.750937 [ 3173 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:56.997525 [ 2761 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.269946 [ 2829 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.751200 [ 3130 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.753070 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.983848 [ 17130 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.984853 [ 2847 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.984992 [ 2996 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.985250 [ 2860 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.985448 [ 2719 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.985711 [ 2873 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.985806 [ 2752 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.986337 [ 3083 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.986737 [ 2806 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.987864 [ 3134 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.988143 [ 2985 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.988441 [ 3196 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.988694 [ 2937 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.989164 [ 3048 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.989421 [ 3146 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.989823 [ 2791 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.989999 [ 3162 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.990309 [ 2834 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.991160 [ 2893 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.991401 [ 3140 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.991665 [ 3072 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.991921 [ 2738 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.992144 [ 2870 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.992447 [ 3119 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.992854 [ 3091 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.993129 [ 3131 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:16:57.993978 [ 3128 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.993985 [ 2890 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.994059 [ 3145 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.994140 [ 2867 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.994156 [ 2801 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:57.998648 [ 2727 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:58.051851 [ 2763 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:58.271028 [ 3120 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:58.751990 [ 2742 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:58.753885 [ 2745 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:59.001779 [ 3172 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:59.271817 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:59.752777 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:16:59.754729 [ 2754 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:00.002724 [ 2844 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:00.272596 [ 2690 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:00.753537 [ 2869 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:00.755330 [ 3193 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:01.003565 [ 2770 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:01.273342 [ 2776 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:01.754925 [ 2980 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:01.756084 [ 2953 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:02.004309 [ 3042 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:02.274218 [ 2863 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:02.755901 [ 3157 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:02.756986 [ 3131 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:03.005310 [ 2779 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:03.275015 [ 2760 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:03.756787 [ 2832 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:03.757888 [ 2809 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:04.006565 [ 2799 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:04.275757 [ 3192 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:04.758911 [ 2868 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:04.759011 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:05.007387 [ 3103 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:05.276441 [ 3028 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:05.759617 [ 2846 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:05.759828 [ 3040 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:06.008320 [ 3145 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:06.277262 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:06.760364 [ 3049 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:06.760651 [ 2763 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:07.009082 [ 2815 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:07.278164 [ 3077 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:07.761168 [ 3010 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:07.761716 [ 3146 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:08.011358 [ 3014 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:08.279097 [ 2712 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:08.762378 [ 3118 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:08.762984 [ 2840 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:09.014190 [ 2906 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:09.279903 [ 2777 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:09.763556 [ 3124 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:09.763908 [ 3177 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:10.015001 [ 2728 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:10.280660 [ 2833 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:10.764892 [ 3137 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:10.764875 [ 2944 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:11.015972 [ 2852 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:11.281444 [ 2911 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:11.766055 [ 2822 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:11.766323 [ 2953 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:12.016842 [ 2910 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:12.282219 [ 2798 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:12.766951 [ 3122 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:12.767247 [ 2687 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:13.017553 [ 2703 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:13.283131 [ 3048 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:13.767770 [ 2747 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:13.767997 [ 2939 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:14.018195 [ 2777 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:14.283846 [ 2755 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:14.768523 [ 2877 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:14.768677 [ 2973 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:15.019160 [ 3110 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:15.284526 [ 2838 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:15.769485 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:15.769508 [ 3040 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:16.019860 [ 2815 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:16.285197 [ 3021 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:16.770683 [ 3094 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:16.854643 [ 2885 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:17.020759 [ 3188 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:17.285852 [ 2958 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:17.771791 [ 2992 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:17.855832 [ 2998 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.021780 [ 3118 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.286769 [ 2964 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.639233 [ 3026 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.639305 [ 3150 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.639390 [ 3167 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.639608 [ 2826 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.639859 [ 3142 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.640371 [ 2693 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.640544 [ 2991 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.640942 [ 3124 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.641152 [ 2947 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.641411 [ 2733 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.641643 [ 3194 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.641770 [ 2936 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.642226 [ 3101 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.642370 [ 3149 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.642855 [ 3081 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.642972 [ 2931 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.643335 [ 2833 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.644603 [ 2827 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.644716 [ 3192 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.645112 [ 2941 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.645287 [ 2784 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.645384 [ 2877 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.645937 [ 2909 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.646000 [ 2821 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:18.647705 [ 3177 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.647979 [ 2818 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.647980 [ 2952 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.647981 [ 3033 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.648174 [ 3184 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.648964 [ 2713 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.650173 [ 3033 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.650244 [ 2952 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.655841 [ 3184 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.696741 [ 3017 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.772670 [ 2845 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:18.856680 [ 2989 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:19.022795 [ 2791 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:19.287465 [ 2683 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:19.774186 [ 3158 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:19.858040 [ 3195 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:20.024030 [ 2684 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:20.288308 [ 2864 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:20.775356 [ 3096 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:20.892046 [ 3116 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:21.025003 [ 3099 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:21.289127 [ 3070 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:21.776543 [ 2682 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:21.893202 [ 2952 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:22.025871 [ 2782 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:22.290017 [ 2817 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:22.777476 [ 3145 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:22.894160 [ 3056 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:23.082724 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:23.291004 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:23.778278 [ 3189 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:23.895123 [ 3038 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:24.083446 [ 2884 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:24.291941 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:24.779397 [ 3188 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:24.895936 [ 2864 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:25.084181 [ 2783 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:25.292615 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:25.780047 [ 3099 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:25.896673 [ 3113 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:26.084935 [ 2751 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:26.293336 [ 2923 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:26.780987 [ 2795 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:26.897345 [ 3181 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:27.085600 [ 3086 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:27.294067 [ 2790 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:27.781740 [ 2877 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:27.898135 [ 3159 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:28.119637 [ 2915 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:28.295121 [ 2953 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:28.782634 [ 3136 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:28.899209 [ 3014 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:29.120784 [ 2756 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:29.296415 [ 2684 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:29.783393 [ 3122 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:29.900197 [ 2887 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:30.121813 [ 3170 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:30.297604 [ 3053 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:30.784132 [ 3165 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:30.901049 [ 2997 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:31.122912 [ 2840 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:31.298332 [ 2799 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:31.321543 [ 30980 ] {f09ba4d6-5c07-4bc4-a13e-ca98d9e4dcec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:42366) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:17:31.322440 [ 30980 ] {f09ba4d6-5c07-4bc4-a13e-ca98d9e4dcec} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:17:31.785041 [ 2697 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:31.901834 [ 2767 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:32.123739 [ 2947 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:32.299204 [ 2829 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:32.751223 [ 29580 ] {560efd9c-c846-44f5-80f6-b13495173bb1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53808) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:17:32.752585 [ 29580 ] {560efd9c-c846-44f5-80f6-b13495173bb1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:17:32.786026 [ 3109 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:32.902659 [ 3028 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:33.124526 [ 3190 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:33.300158 [ 3112 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:33.786940 [ 2904 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:33.903575 [ 3104 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:34.125612 [ 3072 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:34.301938 [ 3083 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:34.787732 [ 3106 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:34.904533 [ 3018 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:35.126607 [ 2902 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:35.302954 [ 2981 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:35.788475 [ 2759 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:35.905310 [ 2948 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:36.039013 [ 3272 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_224_79}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:36.127389 [ 2706 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:36.303911 [ 2754 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:36.789446 [ 3173 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:36.906208 [ 3084 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:37.128129 [ 3190 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:37.304653 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:37.790458 [ 2757 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:37.907371 [ 3148 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:38.128802 [ 2698 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:38.305389 [ 2856 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:38.791417 [ 3088 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:38.908336 [ 3102 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:39.131072 [ 2958 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:39.306246 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:39.793390 [ 2999 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:39.909267 [ 2874 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:40.132107 [ 3044 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:40.307037 [ 2896 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:40.794389 [ 3027 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:40.910207 [ 2973 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:41.133007 [ 2922 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:41.307926 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:41.802948 [ 3173 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:41.911170 [ 2908 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:42.133781 [ 2838 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:42.308804 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:42.803946 [ 2945 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:42.912153 [ 2797 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:43.134918 [ 2891 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:43.309770 [ 2888 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:43.804897 [ 2885 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:43.913199 [ 2843 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:44.135832 [ 2893 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:44.310854 [ 2874 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:44.805631 [ 2741 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:44.913985 [ 2742 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.136593 [ 2810 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.311683 [ 3177 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.383426 [ 2984 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.383691 [ 3133 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.383660 [ 2755 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.383831 [ 3175 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.384063 [ 2924 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.384582 [ 2845 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.384762 [ 2818 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.384863 [ 3025 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.385112 [ 2917 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.385438 [ 2728 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.385605 [ 3160 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.419159 [ 2745 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.419634 [ 2933 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.420063 [ 2826 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.420542 [ 2989 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.420752 [ 2934 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.420997 [ 2952 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.421229 [ 2868 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.421315 [ 2825 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.421638 [ 3033 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.421839 [ 3182 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.422099 [ 2754 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.422678 [ 3066 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.423026 [ 3078 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:17:45.424734 [ 2694 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.424820 [ 3073 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.424847 [ 3027 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.424846 [ 2803 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.424851 [ 2713 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.425039 [ 3079 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.425013 [ 3043 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.425575 [ 2765 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.425604 [ 2922 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.426355 [ 2694 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.426974 [ 3079 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.427492 [ 3043 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.427656 [ 2803 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.427854 [ 2713 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.806440 [ 2965 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:45.915017 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:46.137352 [ 2739 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:46.312389 [ 3077 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:46.807185 [ 3170 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:46.915751 [ 3032 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:47.138035 [ 2715 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:47.313042 [ 2828 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:47.807945 [ 3057 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:47.916574 [ 2959 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:48.138879 [ 2923 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:48.313766 [ 2682 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:48.808621 [ 2716 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:48.917421 [ 3078 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:49.139489 [ 3168 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:49.314408 [ 3097 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:49.809827 [ 2852 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:49.918426 [ 2815 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:50.140405 [ 2732 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:50.315561 [ 3068 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:50.810896 [ 3152 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:50.919605 [ 3166 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:51.141305 [ 2789 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:51.316428 [ 3187 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:51.528670 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3655178d-96ea-42c6-867f-61b9ceac796e::202506_1_172_47}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:51.812042 [ 2885 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:51.920452 [ 3045 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:52.142080 [ 2910 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:52.317274 [ 2695 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:52.812840 [ 2783 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:52.921425 [ 3032 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:53.142856 [ 3072 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:53.318222 [ 3051 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:53.813715 [ 3127 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:53.922293 [ 2706 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:54.143565 [ 3163 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:54.318922 [ 3073 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:54.814816 [ 3024 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:54.923092 [ 2909 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:55.144377 [ 2819 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:55.319833 [ 3161 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:55.815828 [ 2702 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:55.923860 [ 2739 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:56.145147 [ 3037 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:56.320695 [ 2711 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:56.816490 [ 2695 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:56.924526 [ 2814 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:57.145969 [ 2951 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:57.321512 [ 3144 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:57.817117 [ 2850 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:57.925198 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:58.147840 [ 2900 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:58.322720 [ 3096 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:58.817828 [ 2780 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:58.925877 [ 2849 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:59.148876 [ 3092 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:59.323794 [ 2877 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:59.819553 [ 2862 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:17:59.927156 [ 3161 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:00.149709 [ 2800 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:00.324947 [ 2781 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:00.820727 [ 3152 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:00.928298 [ 2928 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:01.150764 [ 3176 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:01.325828 [ 2881 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:01.821640 [ 3170 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:01.929242 [ 2835 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:02.152023 [ 3119 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:02.326899 [ 3012 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:02.822806 [ 3018 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:02.930240 [ 2939 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.153433 [ 2767 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.327836 [ 3177 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.732517 [ 17185 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.733421 [ 2827 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.733538 [ 2819 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.733839 [ 2690 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.733967 [ 2859 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.734283 [ 2972 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.734955 [ 3009 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.735193 [ 3097 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.735461 [ 2979 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.735732 [ 2934 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.735902 [ 3098 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.736120 [ 3109 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.736287 [ 3130 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.736840 [ 2862 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.738158 [ 2933 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.738373 [ 2846 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.738575 [ 2917 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.739036 [ 2818 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.739628 [ 3186 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.739691 [ 2801 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.740090 [ 3025 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.740412 [ 2836 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.740600 [ 3111 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.741034 [ 2761 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.741285 [ 2986 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:03.742461 [ 3182 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.742716 [ 2976 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.742772 [ 3047 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.742786 [ 3108 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.742921 [ 2735 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.742815 [ 3065 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.743037 [ 2731 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.744730 [ 3049 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.744873 [ 2899 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.823598 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:03.930918 [ 2763 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:04.154343 [ 2784 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:04.328619 [ 2789 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:04.824623 [ 3015 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:04.861472 [ 30753 ] {bb8176f7-2f0b-4a12-a882-f1583bb20ecc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:37558) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: SELECT is_done as is_running FROM system.mutations WHERE database==currentDatabase() AND table=='t1'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:18:04.862612 [ 30753 ] {bb8176f7-2f0b-4a12-a882-f1583bb20ecc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:18:04.931685 [ 2747 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:05.155229 [ 2896 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:05.329830 [ 2907 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:05.825569 [ 3011 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:05.932450 [ 2713 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:06.156049 [ 2977 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:06.377415 [ 3026 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:06.826501 [ 2770 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:06.933271 [ 2721 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:07.156767 [ 2888 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:07.378097 [ 2761 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:07.827472 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:07.933968 [ 2873 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:08.157709 [ 3088 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:08.379272 [ 2684 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:08.828229 [ 3032 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:08.934887 [ 2951 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:09.158548 [ 3020 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:09.380358 [ 2938 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:09.829461 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:09.935958 [ 2682 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:10.159786 [ 3183 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:10.381644 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:10.830697 [ 2911 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:10.936871 [ 3056 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:11.160770 [ 3108 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:11.382620 [ 2735 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:11.831573 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:11.937611 [ 2763 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:12.161556 [ 3128 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:12.383758 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:12.832435 [ 2955 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:12.938554 [ 3010 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:13.162462 [ 2837 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:13.385322 [ 2693 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:13.833410 [ 2864 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:13.939598 [ 3022 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:14.163544 [ 2834 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:14.387914 [ 3018 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:14.834373 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:14.940415 [ 2924 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:15.013048 [ 42566 ] {3ba1adfe-3c4d-446f-8536-4a80f6c1febf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:53782) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:18:15.014352 [ 42566 ] {3ba1adfe-3c4d-446f-8536-4a80f6c1febf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:18:15.164432 [ 3016 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:15.388729 [ 2772 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:15.835447 [ 2987 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:15.941216 [ 2991 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:16.165445 [ 2952 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:16.389547 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:16.837228 [ 2994 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:16.942403 [ 3179 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:17.166406 [ 2881 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:17.390593 [ 3062 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:17.838389 [ 2783 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:17.943311 [ 2921 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:18.167348 [ 2804 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:18.391616 [ 3046 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:18.839310 [ 3061 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:18.944300 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:19.168159 [ 3099 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:19.392423 [ 2709 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:19.840118 [ 2713 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:19.945109 [ 2765 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:20.169225 [ 3161 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:20.394030 [ 3066 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:20.840836 [ 2792 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:20.946151 [ 2933 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:21.171153 [ 2839 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:21.480218 [ 2928 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:21.841562 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:21.946939 [ 2789 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:22.172283 [ 3141 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:22.481460 [ 2819 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:22.842210 [ 3032 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:22.947718 [ 2921 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:23.172980 [ 3144 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:23.482386 [ 2912 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:23.842946 [ 2900 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:23.948708 [ 2997 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:24.173580 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:24.539235 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:24.843764 [ 2709 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:24.949657 [ 3019 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:25.174344 [ 3175 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:25.539987 [ 3085 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:25.844492 [ 2825 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:25.950677 [ 2708 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:26.175091 [ 3039 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:26.540845 [ 2830 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:26.845958 [ 3080 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:26.951454 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:27.175831 [ 2994 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:27.542059 [ 2961 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:27.931459 [ 2764 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:27.952960 [ 2884 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:28.176592 [ 2988 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:28.543057 [ 3111 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:28.932457 [ 2841 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:28.954237 [ 2794 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:29.177325 [ 3050 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:29.543799 [ 2811 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:29.933802 [ 2849 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:29.955306 [ 2778 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:30.178274 [ 2973 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:30.544701 [ 3139 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:30.935133 [ 3027 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:30.956157 [ 2832 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:31.179496 [ 2746 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:31.545578 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:31.935926 [ 3194 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:31.956999 [ 3142 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:32.180802 [ 2718 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:32.546466 [ 2816 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:32.936732 [ 3004 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:32.957879 [ 3167 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:33.181683 [ 3092 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:33.547473 [ 3110 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:33.937564 [ 2868 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:33.959227 [ 3192 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:34.182446 [ 3160 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:34.548400 [ 2982 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:34.938420 [ 2984 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:34.960126 [ 2737 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:35.183578 [ 2879 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:35.549133 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:35.939662 [ 3089 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:35.960900 [ 2933 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:36.184689 [ 3025 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:36.549803 [ 2821 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:36.940936 [ 2686 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:36.961705 [ 3148 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:37.185959 [ 2968 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:37.550820 [ 2867 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:37.941949 [ 2972 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:37.962750 [ 2727 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:38.186955 [ 3077 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:38.551646 [ 2963 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:38.942915 [ 3000 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:38.963565 [ 2797 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.187719 [ 3136 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.552523 [ 2707 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.736709 [ 2992 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.736715 [ 3127 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.736751 [ 2700 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.736939 [ 2767 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.736795 [ 2808 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.737260 [ 3127 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.737260 [ 3179 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.737809 [ 3145 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.737867 [ 2795 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.738027 [ 3112 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.738328 [ 2915 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.738648 [ 3005 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.738790 [ 2980 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.739234 [ 2992 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.739617 [ 2870 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.739264 [ 2700 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.739251 [ 3195 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.739561 [ 3074 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.739250 [ 3146 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.739813 [ 3187 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.739848 [ 3067 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.739959 [ 3166 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.740143 [ 3009 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.740208 [ 2795 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.740404 [ 3009 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.740757 [ 2767 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.741407 [ 2957 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.741669 [ 2791 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.741746 [ 2873 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.741842 [ 2885 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.741918 [ 2818 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.742200 [ 2895 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.742770 [ 3014 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.742871 [ 3052 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.744610 [ 2974 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.744920 [ 3010 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:39.746750 [ 2929 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.747969 [ 2929 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.943762 [ 3152 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:39.964488 [ 3060 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:40.188478 [ 2725 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:40.553148 [ 3004 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:40.944529 [ 3125 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:40.965296 [ 2735 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:41.189195 [ 3137 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:41.553880 [ 3168 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:41.945359 [ 2962 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:41.965989 [ 3121 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:42.189865 [ 3054 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:42.554829 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:42.946126 [ 2872 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:43.049963 [ 2895 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:43.190678 [ 3135 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:43.555684 [ 2995 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:43.946879 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:44.050903 [ 2741 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:44.191322 [ 2906 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:44.556515 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:44.947748 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:45.051619 [ 2802 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:45.192173 [ 3033 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:45.557167 [ 3150 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:45.948509 [ 2839 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.052462 [ 3134 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.202358 [ 3000 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.341714 [ 8293 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.343329 [ 3103 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.343853 [ 3037 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.344403 [ 2745 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.344888 [ 2788 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.345369 [ 2740 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.346036 [ 3140 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.346593 [ 2797 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.347213 [ 2845 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.348295 [ 3164 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.348795 [ 2891 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.349252 [ 2789 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.349664 [ 3136 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.350313 [ 2888 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.350909 [ 2754 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.351508 [ 2736 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.353600 [ 2882 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.353887 [ 3193 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.354376 [ 2805 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.354952 [ 2865 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.355446 [ 2994 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.355808 [ 3186 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.356207 [ 2690 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.356773 [ 2990 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.357174 [ 2967 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:46.358359 [ 2727 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.358408 [ 2986 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.358446 [ 2714 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.358713 [ 2807 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.358601 [ 2934 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.358575 [ 2937 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.358549 [ 2953 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.360653 [ 2807 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.360674 [ 2714 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.360873 [ 2953 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.558173 [ 2961 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:46.949385 [ 2774 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:47.053228 [ 3123 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:47.203900 [ 2809 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:47.559130 [ 3059 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:47.950265 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:48.054419 [ 2941 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:48.204803 [ 2911 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:48.560238 [ 3047 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:48.951119 [ 2781 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:49.055761 [ 2897 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:49.205612 [ 2905 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:49.561048 [ 2861 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:49.952115 [ 2739 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:50.056724 [ 2986 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:50.206370 [ 3126 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:50.561731 [ 3071 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:50.952965 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:51.057494 [ 3188 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:51.207276 [ 3014 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:51.562665 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:51.953929 [ 2785 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.058217 [ 2717 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.208073 [ 3127 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.563573 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.826815 [ 17245 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.827499 [ 2981 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.827653 [ 3157 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.827973 [ 2692 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.828196 [ 3017 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.828320 [ 3015 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.828692 [ 2964 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.828713 [ 3175 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.828843 [ 2971 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.829101 [ 2948 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.829395 [ 2722 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.829489 [ 2973 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.829746 [ 3181 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.829812 [ 3096 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.829897 [ 2688 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.830199 [ 3081 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.830867 [ 3027 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.830960 [ 2943 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.831083 [ 2851 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.831185 [ 3114 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.831365 [ 3139 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.832043 [ 2901 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.832045 [ 2832 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.832310 [ 2775 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.834069 [ 2780 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:18:52.834582 [ 2907 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.834725 [ 3177 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.834797 [ 2840 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.835126 [ 2823 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.835207 [ 2818 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.835200 [ 2811 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.835212 [ 2969 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.835390 [ 2769 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.835560 [ 3059 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.836299 [ 3129 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.836470 [ 2818 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.836550 [ 3190 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.837886 [ 3059 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:52.954823 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:53.059022 [ 2937 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:53.208925 [ 2927 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:53.564313 [ 2835 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:53.956708 [ 2990 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:54.059709 [ 3107 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:54.209729 [ 2960 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:54.564960 [ 2884 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:54.957997 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:55.060498 [ 2741 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:55.210455 [ 3116 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:55.565841 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:55.958991 [ 2971 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:56.061575 [ 3149 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:56.211321 [ 3194 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:56.566660 [ 2790 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:56.961645 [ 2905 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:57.062648 [ 3058 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:57.212179 [ 2858 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:57.567578 [ 2718 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:57.963335 [ 3096 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:58.063809 [ 2965 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:58.213041 [ 3148 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:58.568331 [ 3134 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:58.964535 [ 2807 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:59.064744 [ 2917 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:59.214320 [ 2988 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:59.569478 [ 2845 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:18:59.965477 [ 3106 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:00.065820 [ 2929 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:00.215512 [ 2898 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:00.570980 [ 2884 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:00.966450 [ 2896 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:01.066741 [ 2774 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:01.216284 [ 2900 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:01.571934 [ 3019 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:02.012273 [ 2911 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:02.067675 [ 3132 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:02.216992 [ 3047 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:02.572592 [ 2716 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:03.013143 [ 2914 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:03.068749 [ 2686 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:03.218126 [ 3117 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:03.573298 [ 2978 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:04.014993 [ 2955 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:04.069730 [ 2863 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:04.219304 [ 2961 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:04.575258 [ 3021 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.011410 [ 3144 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.011493 [ 2700 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.011669 [ 3062 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.011750 [ 2764 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.011925 [ 3009 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.012029 [ 2808 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.012255 [ 2743 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.012533 [ 2960 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.012733 [ 3046 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.012907 [ 2997 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.013166 [ 2768 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.013299 [ 2788 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.013592 [ 3166 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.013833 [ 2980 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.014080 [ 2766 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.014418 [ 2850 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.014723 [ 2935 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.014828 [ 2710 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.015000 [ 2883 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.015107 [ 2995 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.015502 [ 2898 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.015920 [ 2758 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.016094 [ 3010 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.016250 [ 2828 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.016332 [ 2798 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.016601 [ 2916 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:05.017367 [ 2744 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.017485 [ 3082 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.017623 [ 3141 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.017696 [ 2888 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.017735 [ 2693 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.018021 [ 2881 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.018061 [ 2730 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.018322 [ 2956 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.018351 [ 3146 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.018410 [ 2985 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.018383 [ 2889 ] {} test_9.alter_table_7 (764b68fe-a6f6-4b5d-ae50-c17628a53bc9): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.020642 [ 2885 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.040122 [ 3280 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_185_190_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.070887 [ 2804 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.220089 [ 3136 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.279272 [ 2887 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:05.577587 [ 2948 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:06.017842 [ 2815 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:06.071681 [ 2914 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:06.220877 [ 3134 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:06.578821 [ 2773 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:07.019516 [ 3045 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:07.072527 [ 2691 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:07.221987 [ 2760 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:07.579781 [ 2756 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:08.023797 [ 3119 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:08.073498 [ 2690 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:08.223103 [ 3052 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:08.580762 [ 2938 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:09.025163 [ 2758 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:09.074386 [ 3074 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:09.224038 [ 2883 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:09.581760 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:10.026323 [ 2818 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:10.075210 [ 3083 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:10.224956 [ 2853 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:10.606690 [ 3161 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:11.027416 [ 2694 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:11.075990 [ 2716 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:11.226326 [ 3039 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:11.607630 [ 2753 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:12.028381 [ 2787 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:12.076852 [ 3040 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:12.227206 [ 2807 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:12.608494 [ 2761 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:13.029185 [ 3112 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:13.077845 [ 2895 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:13.227948 [ 2794 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:13.609229 [ 3042 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:14.029958 [ 2916 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:14.079042 [ 3011 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:14.228783 [ 3156 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:14.609872 [ 3092 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:15.030911 [ 2840 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:15.080063 [ 2921 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:15.229506 [ 2685 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:15.611069 [ 2950 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:16.032608 [ 2982 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:16.081153 [ 3104 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:16.230439 [ 3026 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:16.320964 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {751051e6-adca-4665-9806-ed7c89ce0982::202506_1_201_95}: 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa33366 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa30f83 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9bfd97 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa67202 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019e93710 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929ca 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:16.611820 [ 2757 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:17.033653 [ 2862 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:17.082244 [ 2773 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:17.231312 [ 3089 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:17.612523 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:18.035060 [ 2881 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:18.083826 [ 2885 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:18.232184 [ 3042 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:18.613417 [ 2857 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:19.036234 [ 2906 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:19.084794 [ 3073 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:19.232906 [ 2911 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:19.614200 [ 2688 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:20.037232 [ 2750 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:20.085535 [ 2855 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:20.234002 [ 3063 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:20.615120 [ 2734 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:21.038123 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:21.086332 [ 2830 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:21.235319 [ 3096 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:21.615763 [ 3104 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:22.039256 [ 2981 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:22.087188 [ 3197 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:22.236341 [ 2978 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:22.616472 [ 3060 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:23.040050 [ 2720 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:23.087921 [ 2701 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:23.237287 [ 2703 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:23.617205 [ 2926 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:24.040703 [ 2769 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:24.088701 [ 2906 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:24.237953 [ 3043 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:24.617926 [ 3007 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:25.041645 [ 2768 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:25.089510 [ 2790 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:25.239360 [ 2846 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:25.618931 [ 2806 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:26.042517 [ 2684 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:26.090345 [ 2966 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:26.240219 [ 2836 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:26.620813 [ 3181 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:27.043517 [ 2711 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:27.091403 [ 3069 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:27.241245 [ 2842 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:27.622180 [ 2704 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:28.044360 [ 2871 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:28.092349 [ 2881 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:28.242066 [ 2690 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:28.623408 [ 2850 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:29.045528 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:29.093274 [ 2923 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:29.243463 [ 3035 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:29.624232 [ 2849 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:30.046398 [ 3004 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:30.094264 [ 3149 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:30.244631 [ 2977 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:30.501179 [ 3269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {efc9ab92-e475-4973-9a01-6dd22a9c9450::202506_120_210_18}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:30.649783 [ 2945 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:31.047333 [ 3077 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:31.095284 [ 3055 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:31.245907 [ 2821 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:31.650566 [ 2963 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:32.048152 [ 2726 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:32.096163 [ 2812 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:32.247210 [ 2961 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:32.651286 [ 3102 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:33.049173 [ 2740 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:33.096970 [ 3013 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:33.248075 [ 2693 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:33.652240 [ 2860 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:34.050128 [ 2891 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:34.097783 [ 2995 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:34.249270 [ 2809 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:34.653068 [ 2980 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:35.050922 [ 2706 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:35.098580 [ 2743 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:35.250064 [ 3149 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:35.653757 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:36.051528 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:36.099288 [ 3065 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:36.250819 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:36.734869 [ 2904 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:37.052304 [ 2880 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:37.100216 [ 2701 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:37.251403 [ 3013 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:37.735723 [ 3196 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:38.053114 [ 3127 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:38.101286 [ 3180 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:38.252153 [ 2902 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:38.738135 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:39.054040 [ 2854 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:39.103140 [ 2850 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:39.253218 [ 2796 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:39.739718 [ 3046 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:40.055304 [ 3022 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:40.104609 [ 3132 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:40.254209 [ 2958 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:40.740591 [ 2905 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:41.056177 [ 3185 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:41.105499 [ 2858 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:41.254993 [ 3012 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:41.741498 [ 2862 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:42.057077 [ 2961 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:42.106260 [ 2691 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:42.255665 [ 3071 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:42.742734 [ 2756 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.058082 [ 2910 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.107107 [ 3196 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.134090 [ 17142 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.135676 [ 2719 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.135570 [ 2929 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.136132 [ 3070 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.137729 [ 3103 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.137963 [ 2974 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.138569 [ 2996 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.138709 [ 3119 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.139225 [ 2712 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.139870 [ 3127 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.140102 [ 3180 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.140552 [ 2896 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.141074 [ 2860 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.141502 [ 2902 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.141822 [ 2733 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.142113 [ 2690 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.142611 [ 2834 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.143097 [ 2730 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.143487 [ 2764 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.143679 [ 2926 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.143871 [ 2886 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.144463 [ 3072 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.145154 [ 3091 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.145648 [ 3009 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.146205 [ 2854 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.146580 [ 3061 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:43.147497 [ 2703 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.147525 [ 3042 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.147581 [ 2881 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.147670 [ 2913 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.147642 [ 3141 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.147693 [ 2872 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.149335 [ 2703 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.149419 [ 3042 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.149937 [ 2913 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.150075 [ 2903 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.152773 [ 2872 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.256429 [ 2975 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:43.743605 [ 3145 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:44.058929 [ 3017 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:44.107897 [ 2718 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:44.257206 [ 3108 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:44.748321 [ 3155 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:45.060011 [ 2820 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:45.108762 [ 2755 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:45.258277 [ 3175 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:45.749198 [ 2739 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:46.060956 [ 3195 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:46.109708 [ 2904 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:46.259170 [ 3069 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:46.749970 [ 2888 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:47.061664 [ 3062 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:47.110499 [ 3099 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:47.260033 [ 3177 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:47.750663 [ 3018 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:48.062723 [ 2777 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:48.111276 [ 2769 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:48.261840 [ 2741 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:48.751753 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:49.063583 [ 2790 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:49.112269 [ 2831 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:49.262922 [ 2952 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:49.752565 [ 2820 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:50.064318 [ 2787 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:50.113194 [ 3153 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:50.263851 [ 2897 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:50.753336 [ 2724 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:51.065107 [ 2874 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:51.114008 [ 2756 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:51.264633 [ 3051 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:51.754185 [ 2700 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:52.065980 [ 3075 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:52.114931 [ 2878 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:52.265600 [ 2809 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:52.799842 [ 2766 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:53.066966 [ 2725 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:53.115638 [ 3059 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:53.266445 [ 2916 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:53.800885 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.067972 [ 3004 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.116463 [ 2982 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.267471 [ 2943 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.517018 [ 3109 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.517087 [ 3026 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.517273 [ 3182 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.517516 [ 3134 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.517583 [ 2815 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.517680 [ 2817 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.517641 [ 3064 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.519015 [ 3055 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.519241 [ 3065 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.519350 [ 2820 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.519589 [ 2757 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.519742 [ 3148 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.520034 [ 2825 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.520068 [ 2753 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.520269 [ 2807 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.520839 [ 3173 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.521085 [ 2755 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.521317 [ 2822 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.521515 [ 3023 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.521917 [ 3178 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.522125 [ 2879 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.522268 [ 2697 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.522564 [ 3056 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.522823 [ 3054 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.522958 [ 3157 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.523429 [ 2844 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.523530 [ 2735 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:19:54.524492 [ 2707 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.524621 [ 2890 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.524686 [ 2806 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.525204 [ 2972 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.525356 [ 3133 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f4e69e13ac3 23. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.525775 [ 3000 ] {} test_3.replicated_table_for_alter2 (f8813f6b-e2dd-454b-9db9-274751454b33): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:54.801867 [ 2985 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:55.068947 [ 3008 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:55.117435 [ 2923 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:55.268190 [ 3172 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:55.802812 [ 3081 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:56.069935 [ 2733 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:56.118224 [ 3047 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:56.269010 [ 2853 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:56.803457 [ 2802 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:57.070901 [ 2800 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:57.119304 [ 3068 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:57.269966 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:57.804327 [ 2994 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:58.072162 [ 2875 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:58.120113 [ 3165 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:58.272090 [ 2776 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:58.805430 [ 2704 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:59.073429 [ 3173 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:59.120887 [ 2961 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:59.274316 [ 2738 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:19:59.807034 [ 2783 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:00.074798 [ 2998 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:00.121853 [ 3178 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:00.276127 [ 3042 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:00.807899 [ 3095 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:01.075758 [ 3022 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:01.123077 [ 3092 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:01.277001 [ 2849 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:01.809329 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:02.076752 [ 2971 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:02.123945 [ 2742 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:02.277753 [ 3001 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:02.810403 [ 2721 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:03.077651 [ 2892 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:03.124823 [ 3133 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:03.278800 [ 2863 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:03.811261 [ 2826 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:04.078635 [ 2822 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:04.125836 [ 2727 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:04.279514 [ 3071 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:04.812045 [ 3026 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:05.079529 [ 2884 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:05.170962 [ 3180 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:05.280242 [ 3011 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:05.812894 [ 2733 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:06.080961 [ 2950 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:06.172221 [ 2954 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:06.281038 [ 2991 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:06.813931 [ 3137 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:07.081976 [ 2734 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:07.173249 [ 2829 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:07.281784 [ 2710 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:07.868381 [ 3001 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:08.083189 [ 3119 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:08.173989 [ 2846 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:08.282746 [ 3017 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:08.869179 [ 2847 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:09.084092 [ 2692 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:09.174934 [ 3058 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:09.283439 [ 2982 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:09.870117 [ 2852 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:10.084972 [ 2762 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:10.175806 [ 3036 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:10.284039 [ 2947 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:10.870948 [ 3080 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:11.085710 [ 2770 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:11.176552 [ 2984 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:11.284828 [ 2987 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:11.871769 [ 2806 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:12.086491 [ 2981 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:12.177378 [ 2815 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:12.285577 [ 3040 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:12.872483 [ 3134 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:13.087948 [ 2814 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:13.178233 [ 2867 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:13.286856 [ 3189 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:13.873594 [ 2992 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:14.090360 [ 3038 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:14.179144 [ 2994 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:14.288297 [ 2940 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:14.875325 [ 2701 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:15.091431 [ 2760 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:15.179821 [ 3121 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:15.289272 [ 3069 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:15.876449 [ 3013 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.068393 [ 3071 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.068437 [ 2925 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.068542 [ 2761 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.068427 [ 2929 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.068410 [ 3059 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.068466 [ 2750 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.068500 [ 2977 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.068789 [ 2985 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.069297 [ 3147 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.069395 [ 2896 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.069507 [ 2864 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.070952 [ 3059 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.070929 [ 3021 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.070992 [ 2842 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.071232 [ 2925 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.071403 [ 2925 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.071522 [ 2977 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.071555 [ 2929 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.071927 [ 2715 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.072000 [ 2726 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.072403 [ 2841 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.072869 [ 2896 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.073388 [ 2744 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.073443 [ 2767 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.073702 [ 2793 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.073989 [ 2882 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.074635 [ 2872 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.074632 [ 2910 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.075146 [ 3088 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.077066 [ 2975 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.077409 [ 3152 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.077750 [ 2953 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.078049 [ 2990 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.078405 [ 2794 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.078808 [ 2745 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.079166 [ 2805 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:16.082294 [ 3003 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.084140 [ 3003 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.092330 [ 2888 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.180791 [ 2771 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.290290 [ 2903 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:16.877411 [ 2694 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:17.093101 [ 2859 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:17.181697 [ 3017 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:17.291048 [ 2692 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:17.878203 [ 2988 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:18.094065 [ 2901 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:18.182617 [ 2689 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:18.291798 [ 3111 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:18.879180 [ 3013 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:19.095353 [ 3181 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:19.183352 [ 2693 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:19.292922 [ 2864 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:19.879917 [ 3179 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.096168 [ 3188 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.184070 [ 2695 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.293728 [ 2921 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.410184 [ 5641 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.410907 [ 2912 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.410977 [ 2744 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.411079 [ 2841 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.411183 [ 3124 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.411367 [ 2938 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.411645 [ 2900 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.411866 [ 2685 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.411946 [ 2696 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.412096 [ 3085 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.412308 [ 3053 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.412614 [ 3071 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.412886 [ 2743 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.413083 [ 2789 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.413268 [ 2774 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.413545 [ 3091 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.413906 [ 2751 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.414067 [ 3144 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.414091 [ 2999 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.414237 [ 2709 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.414284 [ 3021 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.414288 [ 2951 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.414424 [ 2733 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.416738 [ 2837 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.416789 [ 2810 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:20.417890 [ 2785 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.418020 [ 3081 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.418119 [ 2809 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.418192 [ 2804 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.418265 [ 2916 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.418265 [ 2911 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.418361 [ 2766 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.418728 [ 3061 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.418890 [ 2906 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.419696 [ 3081 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:20.880791 [ 2869 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:21.096855 [ 3182 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:21.184929 [ 2739 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:21.295237 [ 2689 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:21.881588 [ 3032 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:22.097554 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:22.185950 [ 3082 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:22.296479 [ 2795 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:22.882362 [ 2871 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:23.098922 [ 2925 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:23.187138 [ 2969 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:23.297259 [ 3043 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:23.883126 [ 2907 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:24.099826 [ 3113 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:24.188219 [ 3105 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:24.297887 [ 2911 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:24.883804 [ 3063 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:25.100727 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:25.189178 [ 3041 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:25.328951 [ 3029 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:25.884513 [ 3137 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:26.101465 [ 2952 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:26.189980 [ 2999 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:26.329672 [ 3097 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:26.885246 [ 2825 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:27.109062 [ 3182 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:27.190980 [ 2698 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:27.330846 [ 2930 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:27.886165 [ 2759 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:28.111437 [ 2693 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:28.192927 [ 3106 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:28.331721 [ 2720 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:28.640571 [ 23467 ] {af9a3f71-dd56-43bf-97ad-6b05d8178de7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34924) (comment: 02861_alter_replace_partition_do_not_wait_mutations_on_unrelated_partitions.sh) (in query: DROP DATABASE IF EXISTS test_a7x7kb0u ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 2025.06.12 19:20:28.642129 [ 23467 ] {af9a3f71-dd56-43bf-97ad-6b05d8178de7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076333fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000017693322 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c6ee37 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c69f98 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c6919c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f4e69e13ac3 21. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:28.888085 [ 2717 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:29.112324 [ 3140 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:29.194748 [ 2745 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:29.332680 [ 2996 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:29.888878 [ 3190 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:30.113231 [ 3132 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:30.195970 [ 2873 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:30.333872 [ 2870 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:30.889739 [ 2710 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:31.114259 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:31.196785 [ 2688 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:31.334786 [ 2852 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:31.890545 [ 3080 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:32.115288 [ 2820 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:32.197548 [ 2689 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:32.335442 [ 2957 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:32.891245 [ 3052 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:33.115979 [ 3044 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:33.198397 [ 2980 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:33.336170 [ 2884 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:33.892999 [ 2974 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:34.116674 [ 3001 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:34.231296 [ 3149 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:34.337070 [ 3002 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:34.894660 [ 2803 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:35.117962 [ 3078 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:35.232199 [ 2905 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:35.337879 [ 2702 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:35.895601 [ 3195 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:36.119014 [ 2845 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:36.233140 [ 3098 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:36.338837 [ 2691 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:36.896734 [ 2961 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:37.119884 [ 3034 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:37.234012 [ 2923 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:37.339630 [ 2700 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:37.897533 [ 3073 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:38.120738 [ 2924 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:38.235331 [ 3187 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:38.340475 [ 3136 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:38.898368 [ 2974 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:39.121901 [ 2768 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:39.236447 [ 3001 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:39.341285 [ 2713 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:39.899367 [ 2855 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.123024 [ 2939 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.237247 [ 2837 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.327165 [ 17196 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f4e69e13ac3 12. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.327964 [ 3039 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.328073 [ 2999 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.328149 [ 2909 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.328366 [ 2900 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.328631 [ 2912 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.329951 [ 2692 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.330038 [ 2732 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.330376 [ 3064 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.330609 [ 3021 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.330972 [ 3168 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.331614 [ 3142 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.331763 [ 2775 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.332105 [ 2947 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.332429 [ 3016 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.332670 [ 2847 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.332976 [ 2770 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.333284 [ 3162 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.333616 [ 2821 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.333686 [ 2749 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.334089 [ 3006 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.334404 [ 3097 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.334729 [ 2914 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.335206 [ 3171 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.335581 [ 2972 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:20:40.336573 [ 2702 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.336711 [ 3137 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.336789 [ 3104 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.336780 [ 2725 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.336797 [ 3012 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.336988 [ 2831 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.336804 [ 3161 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.341930 [ 2890 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:40.900242 [ 3083 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:41.123940 [ 3090 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:41.238287 [ 3018 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:41.342841 [ 2804 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:41.901517 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:42.124842 [ 3050 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:42.239070 [ 2941 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:42.343626 [ 2718 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:42.902600 [ 3086 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:43.125650 [ 2803 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:43.240232 [ 3104 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:43.344457 [ 2981 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:43.903327 [ 2848 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:44.147083 [ 2839 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:44.241592 [ 3182 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:44.345302 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:44.904115 [ 3111 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:45.148017 [ 2874 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:45.242427 [ 2708 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:45.346179 [ 3176 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:45.904842 [ 3069 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:46.148899 [ 2946 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:46.243433 [ 2700 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:46.347015 [ 3059 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:46.905694 [ 3107 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:47.149889 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:47.244505 [ 2785 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:47.348158 [ 3123 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:47.990900 [ 2766 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:48.151675 [ 2853 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:48.245622 [ 2938 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:48.349402 [ 2768 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:48.991653 [ 3005 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:49.152649 [ 3108 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:49.246422 [ 2716 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:49.350343 [ 3071 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:49.992380 [ 2966 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:50.153414 [ 2781 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:50.247325 [ 2863 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:50.351196 [ 2947 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:50.993093 [ 2786 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:51.154153 [ 3003 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:51.248101 [ 2977 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:51.352074 [ 3177 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:51.994123 [ 3083 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:52.154895 [ 2907 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:52.248947 [ 2818 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:52.364166 [ 3018 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:52.995234 [ 2974 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:53.155718 [ 3001 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:53.249770 [ 3024 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:53.364853 [ 3050 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:53.912985 [ 29580 ] {86ef9165-a238-4f12-95e6-0dbbfa4804fc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:57322) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:20:53.914204 [ 29580 ] {86ef9165-a238-4f12-95e6-0dbbfa4804fc} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:20:54.006393 [ 2705 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:54.156564 [ 2722 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:54.250885 [ 2821 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:54.365588 [ 2942 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:55.007748 [ 2735 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:55.157401 [ 3000 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:55.251971 [ 2776 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:55.366493 [ 2903 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:56.008562 [ 2896 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:56.158314 [ 3183 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:56.252867 [ 3121 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:56.367491 [ 2860 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:56.945938 [ 29580 ] {c858f638-c4a3-434e-818b-abc215fed8de} 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.10057.altinitytest (altinity build)) (from [::1]:57346) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:20:56.950827 [ 29580 ] {c858f638-c4a3-434e-818b-abc215fed8de} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:20:57.009424 [ 3046 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:57.159375 [ 2834 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:57.253794 [ 2985 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:57.368350 [ 3179 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:58.010586 [ 3152 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:58.160782 [ 2996 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:58.254990 [ 2920 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:58.369130 [ 3118 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:59.012505 [ 2713 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:59.162168 [ 2751 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:59.256112 [ 2710 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:20:59.370081 [ 3192 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:00.013420 [ 2762 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:00.163472 [ 2810 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:00.256984 [ 2952 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:00.371127 [ 2792 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:01.014320 [ 2979 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:01.164612 [ 2736 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:01.257850 [ 2689 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:01.372095 [ 3023 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:02.015783 [ 3003 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:02.165568 [ 3074 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:02.258859 [ 2786 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:02.372826 [ 2913 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:03.016955 [ 2919 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:03.166385 [ 3055 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:03.259612 [ 2918 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:03.373526 [ 2911 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:04.018035 [ 3010 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:04.168216 [ 2849 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:04.260719 [ 2938 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:04.374457 [ 2989 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:05.018875 [ 3108 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:05.168993 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:05.261558 [ 2952 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:05.375216 [ 3036 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:06.019561 [ 2847 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:06.169671 [ 2825 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:06.262744 [ 3112 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:06.375938 [ 3016 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:07.020373 [ 2965 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:07.170440 [ 2955 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:07.263949 [ 2879 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:07.443390 [ 3170 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:08.021129 [ 2990 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:08.171521 [ 2960 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:08.264830 [ 3118 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:08.444244 [ 2766 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:09.022028 [ 3009 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:09.173688 [ 2849 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:09.265662 [ 2719 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:09.445144 [ 2741 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:10.022785 [ 2696 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:10.174531 [ 2846 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:10.266624 [ 2721 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:10.445884 [ 2868 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:11.023680 [ 3111 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:11.175686 [ 2963 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:11.211040 [ 29580 ] {94a83804-c643-4e7c-9538-a00806eb9339} 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.10057.altinitytest (altinity build)) (from [::1]:44868) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:21:11.212060 [ 29580 ] {94a83804-c643-4e7c-9538-a00806eb9339} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a6cb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f4e69e13ac3 15. ? @ 0x00007f4e69ea5850 2025.06.12 19:21:11.267368 [ 3023 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:11.447120 [ 2827 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:12.025464 [ 2835 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:12.176920 [ 2776 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:12.269422 [ 2738 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:12.448219 [ 3039 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:13.026257 [ 2913 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:13.177718 [ 2715 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:13.358165 [ 3043 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:13.449194 [ 2745 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:13.789311 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5665db54-8a60-44ef-bebe-0b7ee2ad0454::202506_197_202_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000001996bbda 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001996c51a 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1046: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000199723f4 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000199720ce 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 30. __tsan_thread_start_func @ 0x000000000758af2f 31. ? @ 0x00007f4e69e13ac3 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:14.026951 [ 2938 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:14.208342 [ 2853 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:14.359207 [ 3163 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:14.418050 [ 3276 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_253_108}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:14.450076 [ 3030 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:15.028095 [ 3049 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:15.209960 [ 2852 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:15.360071 [ 3108 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:15.451127 [ 2816 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:16.028991 [ 2825 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:16.211174 [ 2827 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:16.360911 [ 3195 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:16.451949 [ 2691 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:17.029765 [ 2703 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:17.211987 [ 2865 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:17.361715 [ 2998 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:17.452782 [ 2929 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:18.030664 [ 2960 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:18.212748 [ 2854 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:18.362664 [ 3124 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:18.453504 [ 2853 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:19.031505 [ 2699 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:19.213868 [ 3086 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:19.363673 [ 2725 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:19.454424 [ 3096 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:20.032311 [ 2803 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:20.215164 [ 2744 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:20.364446 [ 2945 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:20.455228 [ 3133 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:21.032977 [ 2826 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:21.218081 [ 2897 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:21.365251 [ 3039 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:21.455880 [ 3064 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:22.034172 [ 2717 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:22.219902 [ 3083 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:22.366510 [ 3072 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:22.457083 [ 3147 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:22.462566 [ 3279 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c86f717d-83e3-4b01-97b8-8250998cbdff::202506_1_233_47}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:22.636493 [ 3277 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c86f717d-83e3-4b01-97b8-8250998cbdff::202506_1_233_47}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=26, 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f4e69e13ac3 31. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:23.035154 [ 3184 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:23.220974 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:23.367885 [ 3009 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:23.458014 [ 3149 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:24.036131 [ 2763 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:24.222048 [ 2964 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:24.368777 [ 3071 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:24.459226 [ 2784 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:25.036944 [ 3144 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:25.223127 [ 2895 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:25.369576 [ 2752 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:25.460146 [ 2863 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:26.037723 [ 2727 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:26.223902 [ 2775 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:26.370813 [ 3126 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:26.460915 [ 3020 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:27.038759 [ 2745 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:27.224772 [ 2969 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:27.371764 [ 3011 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:27.461612 [ 3196 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:28.039511 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:28.225586 [ 2765 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:28.372481 [ 2830 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:28.462197 [ 3029 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:29.040231 [ 2831 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:29.226268 [ 3053 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:29.373124 [ 2936 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:29.463018 [ 2930 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:30.041039 [ 2888 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:30.227032 [ 3069 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:30.373959 [ 2735 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:30.486738 [ 2915 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:31.042441 [ 2842 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:31.228475 [ 2916 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:31.375031 [ 2730 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:31.488525 [ 2873 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:32.043360 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:32.229669 [ 2921 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:32.376247 [ 2931 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:32.489458 [ 3149 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:33.044166 [ 2906 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:33.230644 [ 3139 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:33.377403 [ 3180 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:33.490840 [ 3022 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:34.044955 [ 2764 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:34.231396 [ 2855 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:34.378349 [ 2803 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:34.492260 [ 2892 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:35.045750 [ 3111 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:35.232395 [ 2733 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:35.379312 [ 2686 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:35.493365 [ 2934 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:36.046815 [ 3126 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:36.233425 [ 2977 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:36.380376 [ 3065 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:36.494232 [ 2879 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:37.047564 [ 2894 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:37.234238 [ 2985 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:37.381271 [ 3048 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:37.495492 [ 3095 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:38.048385 [ 2938 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:38.235389 [ 3163 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:38.382064 [ 2948 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:38.497270 [ 2731 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:39.049047 [ 3005 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:39.236388 [ 2784 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:39.383034 [ 2958 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:39.498157 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:40.049753 [ 3167 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:40.237263 [ 3096 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:40.383838 [ 2862 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:40.499049 [ 2825 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:41.050440 [ 3164 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:41.237999 [ 2715 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:41.384863 [ 2745 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:41.500070 [ 3046 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:42.051468 [ 3122 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:42.239132 [ 2989 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:42.385788 [ 3146 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:42.500869 [ 3029 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:43.052309 [ 2830 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:43.240210 [ 2817 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:43.386786 [ 2833 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:43.501822 [ 3161 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:44.053009 [ 2821 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:44.241070 [ 2825 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:44.387777 [ 2928 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:44.502896 [ 2686 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:45.053707 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:45.242307 [ 2820 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:45.388815 [ 2704 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:45.503741 [ 3094 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:46.054669 [ 2860 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:46.243235 [ 2956 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:46.389762 [ 2717 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:46.504602 [ 2926 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:47.055575 [ 2703 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:47.244312 [ 2759 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:47.390812 [ 2923 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:47.505342 [ 2864 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:48.056364 [ 2922 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:48.245678 [ 2683 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:48.391572 [ 3046 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:48.506116 [ 2882 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:49.057192 [ 3011 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:49.247124 [ 2692 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:49.392376 [ 3129 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:49.507346 [ 2695 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:50.057953 [ 3043 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:50.248032 [ 2935 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:50.393214 [ 2975 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:50.508098 [ 2842 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:51.059089 [ 2938 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:51.248846 [ 2970 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:51.394009 [ 2971 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:51.508946 [ 2741 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:52.059909 [ 2870 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:52.249704 [ 2802 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:52.395208 [ 3010 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:52.509891 [ 2819 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:53.060768 [ 3101 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:53.331879 [ 2769 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:53.395989 [ 3124 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:53.510835 [ 2694 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:54.061681 [ 3192 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:54.332825 [ 3159 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:54.396802 [ 3194 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:54.511674 [ 3119 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:55.062685 [ 2973 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:55.333857 [ 3088 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:55.397620 [ 3015 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:55.512574 [ 2774 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.063498 [ 2699 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.335529 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.398723 [ 2784 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.440035 [ 2760 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.440293 [ 2732 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.440436 [ 2791 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.440454 [ 3062 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.440543 [ 2767 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.440540 [ 2684 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.441344 [ 2710 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.441554 [ 2831 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.441668 [ 2869 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.441850 [ 3150 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.442079 [ 2887 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.442645 [ 2684 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.442725 [ 2760 ] {} test_9.alter_table_8 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.442814 [ 3167 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.442862 [ 3062 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.442953 [ 2816 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.442995 [ 2791 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.443236 [ 2732 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.443493 [ 2732 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.443535 [ 2767 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.443666 [ 3108 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.444051 [ 2852 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.444313 [ 2772 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.444616 [ 3047 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.444776 [ 2803 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.444903 [ 3058 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.445660 [ 3175 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.445739 [ 2777 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.446089 [ 2725 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.447328 [ 2954 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.447679 [ 2716 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.448079 [ 2682 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.448326 [ 2945 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.448488 [ 3161 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.449074 [ 2939 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.449407 [ 2832 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:21:56.450589 [ 2999 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.450620 [ 2788 ] {} test_3.i20203_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/test_3/01715_background_checker_i20203/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.450671 [ 3052 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.450797 [ 2889 ] {} test_15.data_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/data/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.450821 [ 3048 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest2/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.450833 [ 2985 ] {} test_15.data_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/data/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.450825 [ 3070 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.451984 [ 3040 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f4e69e13ac3 18. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.453338 [ 3040 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:56.513293 [ 2866 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:57.064179 [ 2717 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:57.336571 [ 3042 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:57.399779 [ 3072 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:57.513924 [ 2782 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:58.064944 [ 3055 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:58.337449 [ 2873 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:58.400544 [ 2854 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:58.514805 [ 3110 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:59.065793 [ 2906 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:59.338439 [ 2742 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:59.401257 [ 3192 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:21:59.515617 [ 2993 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:00.066764 [ 2908 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:00.339497 [ 2702 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:00.402014 [ 3084 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:00.516610 [ 3100 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:01.067625 [ 3197 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:01.340657 [ 3064 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:01.403029 [ 2693 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:01.517591 [ 2877 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:02.068338 [ 3168 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:02.341924 [ 2926 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:02.404449 [ 2953 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:02.518710 [ 3121 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:02.761257 [ 29580 ] {8bbcbbeb-11fc-4b33-a010-c5aa0faa7bae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:56520) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM system.zookeeper WHERE path like '/clickhouse/tables/02515_cleanup_async_insert_block_ids_test_3/test_3/t_async_insert_cleanup/async_blocks%' settings allow_unrestricted_reads_from_keeper = 'true'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:22:02.763743 [ 29580 ] {8bbcbbeb-11fc-4b33-a010-c5aa0faa7bae} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=928, jobs=781). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb1df58 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1646e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb17057 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f4427 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a2f4a07 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e60dc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d8f9f 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f4e69e13ac3 19. ? @ 0x00007f4e69ea5850 2025.06.12 19:22:03.069220 [ 2896 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:03.343074 [ 3042 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:03.405807 [ 3026 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:03.519731 [ 2759 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:04.070029 [ 3145 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:04.343964 [ 2746 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:04.406845 [ 2811 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:04.520575 [ 2980 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:05.071210 [ 2729 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:05.344932 [ 3194 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:05.407969 [ 2718 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:05.521304 [ 3036 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:06.072382 [ 2887 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:06.346045 [ 2939 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:06.409251 [ 2979 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:06.522108 [ 3176 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:07.073644 [ 3165 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:07.347089 [ 3012 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:07.410723 [ 3023 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:07.523013 [ 3020 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:08.074836 [ 3075 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:08.348432 [ 3135 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:08.411835 [ 3072 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:08.523906 [ 2919 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:09.075982 [ 2805 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:09.349383 [ 3024 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:09.412813 [ 2971 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:09.524790 [ 2712 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:10.077025 [ 2944 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:10.350200 [ 2841 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:10.413692 [ 2789 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:10.525521 [ 3036 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:11.079126 [ 3100 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:11.351570 [ 2954 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:11.415113 [ 3014 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:11.526348 [ 2808 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:12.080359 [ 2847 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:12.352633 [ 2871 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:12.416428 [ 2860 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:12.527438 [ 3094 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:13.081721 [ 3157 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:13.209591 [ 29580 ] {97f3b476-9c91-487f-9bc8-e00e59f12856} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_async_insert_cleanup' in scope SELECT count(*) FROM t_async_insert_cleanup. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33784) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: SELECT count(*) FROM t_async_insert_cleanup), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:22:13.210922 [ 29580 ] {97f3b476-9c91-487f-9bc8-e00e59f12856} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_async_insert_cleanup' in scope SELECT count(*) FROM t_async_insert_cleanup. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082eee86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cd5ac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749151c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017490487 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001748f8e5 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c86727 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&) @ 0x0000000017db93b0 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db60a0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dba6f0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3850e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 22. __tsan_thread_start_func @ 0x000000000758af2f 23. ? @ 0x00007f4e69e13ac3 24. ? @ 0x00007f4e69ea5850 2025.06.12 19:22:13.353445 [ 2990 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:13.417309 [ 2925 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:13.528839 [ 3140 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:14.082673 [ 3035 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:14.211864 [ 29580 ] {774ea07e-03db-4097-b8b4-405fe812b4d4} executeQuery: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup does not exist. (UNKNOWN_TABLE) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:33794) (comment: 02515_cleanup_async_insert_block_ids.sh) (in query: DROP TABLE t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696fa4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a83b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:22:14.213129 [ 29580 ] {774ea07e-03db-4097-b8b4-405fe812b4d4} TCPHandler: Code: 60. DB::Exception: Table test_3.t_async_insert_cleanup 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007614406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171391e3 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000001768f9e1 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000017696fa4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c6a83b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c69cf5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c690a9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c68df0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018212338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d8dfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f8668 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007f4e69e13ac3 22. ? @ 0x00007f4e69ea5850 2025.06.12 19:22:14.354541 [ 2883 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:14.418076 [ 3163 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:14.529720 [ 2870 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:15.083546 [ 2789 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:15.355677 [ 3033 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:15.419132 [ 2976 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:15.530590 [ 2762 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:16.084363 [ 2682 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:16.356565 [ 3182 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:16.419930 [ 2987 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:16.531498 [ 2858 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:17.085251 [ 3127 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:17.357261 [ 3068 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:17.420826 [ 3045 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:17.532263 [ 3020 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:18.086233 [ 2893 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:18.358101 [ 2849 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:18.421873 [ 2782 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:18.533071 [ 2994 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:19.087093 [ 2915 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:19.359086 [ 2717 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:19.423163 [ 2701 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:19.558882 [ 3189 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:20.088069 [ 3147 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:20.360153 [ 2971 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:20.424132 [ 2923 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:20.564155 [ 2910 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:21.089155 [ 2713 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:21.360910 [ 3153 ] {} test_1a87k00g.enum_alter_issue (f8b3894e-6d4f-4772-b603-add6993bacc7): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:21.425132 [ 3015 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:22:21.567069 [ 2979 ] {} test_slupgmk5.replicated_with_sampling (bc9edad3-d2bc-4955-bafc-40fc54110f02): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f4e69e13ac3 14. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:23:21.937940 [ 45739 ] {2b6846de-f67d-499e-8725-82a0c754d1ae} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.088817522 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:34146) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfd406 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfc526 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edeb41 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e19a8 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e15e8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007f4e69e13ac3 13. ? @ 0x00007f4e69ea5850 2025.06.12 19:23:21.939064 [ 45739 ] {2b6846de-f67d-499e-8725-82a0c754d1ae} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.088817522 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfd406 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfc526 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edeb41 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e19a8 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e15e8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007f4e69e13ac3 13. ? @ 0x00007f4e69ea5850 2025.06.12 19:23:22.740240 [ 42566 ] {62ffea11-e90f-4ba9-abe9-4f82c981c9a5} 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.10057.altinitytest (altinity build)) (from [::1]:54432) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000170bbe88 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000170bbbc4 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000170bb5d0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c30f4c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 2025.06.12 19:23:22.741332 [ 42566 ] {62ffea11-e90f-4ba9-abe9-4f82c981c9a5} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000170bbe88 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000170bbbc4 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000170bb5d0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c30f4c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1983: DB::InterpreterCreateQuery::execute() @ 0x0000000017c50cdc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216e07 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&)>) @ 0x000000001821af79 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a12f4cd 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a133659 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20bafb 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a1903 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a2172 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61b383 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e619650 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e617b2a 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f4e69e13ac3 20. ? @ 0x00007f4e69ea5850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:23:45.408090 [ 2652 ] {} Application: Closed all listening sockets. Waiting for 10 outstanding connections. 2025.06.12 19:23:50.315773 [ 2652 ] {} Application: Closed connections. But 10 remain. Tip: To increase wait time add to config: 60 2025.06.12 19:23:50.315956 [ 2652 ] {} Application: Will shutdown forcefully. 2025.06.12 19:23:52.139134 [ 45795 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.06.12 19:23:52.181153 [ 45795 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.06.12 19:23:52.182895 [ 45795 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.06.12 19:23:52.184129 [ 45795 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.06.12 19:23:53.688924 [ 45795 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.12 19:23:53.698752 [ 45795 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.12 19:23:53.698801 [ 45795 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.12 19:23:53.755213 [ 46392 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.12 19:23:57.670725 [ 45795 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.06.12 19:23:58.336879 [ 45795 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.06.12 19:23:58.389903 [ 45795 ] {} DatabaseReplicated (test_0d9ohxyx): Database test_0d9ohxyx exists locally, but its replica does not exist in ZooKeeper (/test/db/test_14/replicas/s1|r1). Assuming it was dropped, will not try to start it up 2025.06.12 19:23:58.509869 [ 45795 ] {} TablesLoader: Tables test_ionlee1e.test_dictionary_2 depend on test_ionlee1e.`{CLICKHOUSE_DATABASE:String}.dictionary_table`, but seems like that does not exist. Will ignore it and try to load existing tables 2025.06.12 19:23:59.689173 [ 45803 ] {c117e97c-c3d8-419e-a60a-73950f818a46} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10057.altinitytest (altinity build)) (from [::1]:35332) (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f00a651fac3 15. ? @ 0x00007f00a65b1850 2025.06.12 19:23:59.690401 [ 45803 ] {c117e97c-c3d8-419e-a60a-73950f818a46} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2e3012 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2e181b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e157f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f595b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007f00a651fac3 15. ? @ 0x00007f00a65b1850 2025.06.12 19:24:00.732562 [ 46522 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f00a651fac3 12. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.733273 [ 46066 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.733309 [ 46087 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.733450 [ 46000 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.733664 [ 46102 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.733743 [ 46097 ] {} test_slupgmk5.replicated_with_sampling (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.733808 [ 46085 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.734038 [ 46071 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.734325 [ 46074 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.734458 [ 46086 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.734742 [ 46092 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.735052 [ 46076 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.735396 [ 46098 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.735740 [ 46099 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.735833 [ 46105 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.735907 [ 45999 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.736070 [ 46094 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.736480 [ 46078 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.736652 [ 46089 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.736858 [ 46110 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.736928 [ 46100 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.737021 [ 46104 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.737116 [ 46113 ] {} test_1a87k00g.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.737336 [ 46114 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.737646 [ 46103 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.737791 [ 46093 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.738392 [ 46106 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:00.850768 [ 46053 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4230e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.852212 [ 46064 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.866841 [ 46107 ] {} test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02369/02369_lost_part_intersecting_merges_test_9/test_9/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.881021 [ 46063 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.881073 [ 46049 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.881101 [ 46060 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.885282 [ 46112 ] {} test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.898269 [ 46036 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.898411 [ 46073 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.957044 [ 46063 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.957115 [ 46060 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.957219 [ 46036 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:00.957249 [ 46073 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:01.329704 [ 46522 ] {} 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000001ae51f00 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000001ae50ac0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000001ae500f4 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*) @ 0x000000001ae58593 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 10. __tsan_thread_start_func @ 0x000000000758af2f 11. ? @ 0x00007f00a651fac3 12. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:01.331175 [ 46118 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.331345 [ 46130 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.331586 [ 46124 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.332014 [ 46102 ] {} test_slupgmk5.replicated_with_sampling (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.332507 [ 46128 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.333020 [ 46096 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.333516 [ 46011 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.333754 [ 46089 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.334238 [ 46095 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.334499 [ 46136 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.334977 [ 46151 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.335762 [ 45999 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.336244 [ 46140 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.336470 [ 46131 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.336848 [ 46129 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.337049 [ 46139 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.337519 [ 46155 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.337696 [ 46150 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.338426 [ 46157 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.338871 [ 46101 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.339009 [ 46156 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.339282 [ 46119 ] {} test_1a87k00g.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.339604 [ 46159 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.340032 [ 46166 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.340330 [ 46144 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.340691 [ 46038 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:01.342489 [ 46056 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_1/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:01.342590 [ 46075 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_5/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:01.342659 [ 46080 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:01.342693 [ 46116 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:01.497801 [ 46081 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:01.498557 [ 46115 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:01.499558 [ 46054 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.229204 [ 46238 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.229266 [ 46095 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.229424 [ 46293 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.229505 [ 46199 ] {} test_slupgmk5.replicated_with_sampling (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.229650 [ 46118 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.229775 [ 46139 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.229988 [ 46169 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.230355 [ 46153 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.230565 [ 46280 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.230661 [ 46185 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.230846 [ 46189 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.230906 [ 46155 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.231388 [ 46225 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.231599 [ 46215 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.231675 [ 46256 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.231746 [ 46274 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.232004 [ 46177 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.232010 [ 46231 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.232270 [ 46205 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.232264 [ 46276 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.232355 [ 46202 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.233162 [ 46284 ] {} test_1a87k00g.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.233328 [ 46271 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.233476 [ 46032 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.233660 [ 46298 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.234117 [ 46064 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:02.235905 [ 46278 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_4/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.236224 [ 46147 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_7/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.236240 [ 46188 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.236411 [ 46272 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.236539 [ 46107 ] {} test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.236641 [ 46186 ] {} test_3.replicated_table_for_alter1 (ef8c92c4-8fc3-457f-927a-a11dbe36ea95): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.238741 [ 46102 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.306515 [ 46248 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.306654 [ 46254 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.353720 [ 46074 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f00a651fac3 23. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:02.372498 [ 46237 ] {} test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000019d81cd4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000193cb8a0 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.014239 [ 46303 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.014403 [ 46076 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.014488 [ 46323 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.014719 [ 45867 ] {} test_slupgmk5.replicated_with_sampling (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.014773 [ 46257 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.014887 [ 46313 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.015119 [ 46288 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.015265 [ 46201 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.015458 [ 45829 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.015693 [ 45840 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.015971 [ 46106 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.016153 [ 46110 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.016319 [ 45831 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.016505 [ 46177 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.016715 [ 45832 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.016929 [ 46336 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.017048 [ 46101 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.017329 [ 45890 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.017526 [ 46319 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.017896 [ 46339 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.018129 [ 45835 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.018266 [ 45837 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.018467 [ 46036 ] {} test_1a87k00g.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.018562 [ 46321 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.018647 [ 46248 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.018897 [ 45869 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.019289 [ 46060 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:03.019980 [ 45866 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/host. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.020283 [ 45862 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_8/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d42c29 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.020275 [ 46254 ] {} test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02369/02369_lost_part_intersecting_merges_test_9/test_9/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.020306 [ 46306 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.020403 [ 46131 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000001ae53ab8 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000001add3727 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000001add316c 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add40de 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001add3ae3 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4297e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f00a651fac3 23. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.020539 [ 46072 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40f07 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.020570 [ 45884 ] {} test_9.rmt1 (c56164b3-41d0-412e-b0af-1c8346846a14): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.097710 [ 46582 ] {} TransactionLog: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/clickhouse/txn/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:58: zkutil::ZooKeeper::sync(String const&) @ 0x000000001add638d 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::TransactionLog::runUpdatingThread() @ 0x00000000181097cd 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000018115d86 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000018115ca2 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007f00a651fac3 13. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.107473 [ 46121 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 19. __tsan_thread_start_func @ 0x000000000758af2f 20. ? @ 0x00007f00a651fac3 21. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.116644 [ 46313 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest2/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest2/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.116784 [ 46201 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_15/data/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/data/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.116963 [ 46313 ] {} test_15.replace_partition_dest2_2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.117043 [ 46201 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.116985 [ 46106 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117011 [ 45829 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117420 [ 45835 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117490 [ 46248 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /test/02271_replace_partition_many/test_15/dest2/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /test/02271_replace_partition_many/test_15/dest2/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117120 [ 45831 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/test_00732/quorum_have_data/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117593 [ 46106 ] {} test_15.replace_partition_dest1_2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.117610 [ 45829 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.117472 [ 45890 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02922/test_9/table/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02922/test_9/table/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117662 [ 45835 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.117462 [ 45840 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/source/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/source/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117460 [ 46036 ] {} test_1a87k00g.enum_alter_issue (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_1a87k00g/test_02012/enum_alter_issue/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117516 [ 46288 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_9/rep_data/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_9/rep_data/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117495 [ 46319 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.117672 [ 45869 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/test_00980_test_3/replicated_table_for_alter/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.118071 [ 45831 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.118068 [ 45840 ] {} test_15.replace_partition_source (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.117779 [ 46248 ] {} test_15.replace_partition_dest2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.117988 [ 46339 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_15/dest1/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.118253 [ 46321 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /clickhouse/tables/test_15/data/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/test_15/data/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.118533 [ 46101 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.118564 [ 46319 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.118643 [ 46110 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.118670 [ 46177 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.118790 [ 46101 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.118700 [ 45890 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.118690 [ 46288 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.118755 [ 46339 ] {} test_15.replace_partition_dest1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.118741 [ 46323 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.118748 [ 46060 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /test/02369/02369_lost_part_intersecting_merges_test_9/test_9/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /test/02369/02369_lost_part_intersecting_merges_test_9/test_9/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.118768 [ 45869 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.119031 [ 46110 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.119084 [ 46323 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.118381 [ 46036 ] {} test_1a87k00g.enum_alter_issue (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.119081 [ 46321 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.119196 [ 46177 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.119172 [ 45832 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_parts. Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/quorum/failed_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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.119374 [ 46060 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.119762 [ 45832 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.124303 [ 46303 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/test_3/01715_background_checker_i20203/replicas/r2/is_active. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/test_3/01715_background_checker_i20203/replicas/r2/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1057: zkutil::ZooKeeper::deleteEphemeralNodeIfContentMatches(String const&, String const&) @ 0x000000001addbd24 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:0: DB::ReplicatedMergeTreeRestartingThread::activateReplica() @ 0x0000000019dd2481 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:172: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.124433 [ 46076 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/2/is_active. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/00446_clear_column_in_partition_concurrent_zookeeper_test_9/tables/clear_column_concurrent/replicas/2/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1057: zkutil::ZooKeeper::deleteEphemeralNodeIfContentMatches(String const&, String const&) @ 0x000000001addbd24 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:0: DB::ReplicatedMergeTreeRestartingThread::activateReplica() @ 0x0000000019dd2481 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:172: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.124454 [ 45867 ] {} test_slupgmk5.replicated_with_sampling (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Session expired, path /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1/is_active. Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/test_slupgmk5/test_00509/replicated_with_sampling/replicas/r1/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1057: zkutil::ZooKeeper::deleteEphemeralNodeIfContentMatches(String const&, String const&) @ 0x000000001addbd24 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:0: DB::ReplicatedMergeTreeRestartingThread::activateReplica() @ 0x0000000019dd2481 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:172: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.124572 [ 46303 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.124698 [ 46076 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.124892 [ 45867 ] {} test_slupgmk5.replicated_with_sampling (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:03.141971 [ 46336 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Session expired (fault injected on send). 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000019df572b 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000001ae5a28a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000001ae529a0 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae52566 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:266: DB::ReplicatedMergeTreeRestartingThread::removeFailedQuorumParts() @ 0x0000000019dd178a 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:170: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000019dcf6f1 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:141: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000019dce3f2 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:68: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x0000000019dcd62c 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019dd8b62 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 21. __tsan_thread_start_func @ 0x000000000758af2f 22. ? @ 0x00007f00a651fac3 23. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:03.142146 [ 46336 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.12 19:24:12.112654 [ 46437 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2729348d-6b1f-45da-afd8-2c45d281eb7b::202506_1_279_130}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb1e06c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb206f8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb19cce 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb19a0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b9367d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b8fd50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b8fa21 10. ./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) @ 0x0000000019bbcf76 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019aa4872 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aa0d6b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019bf3ccf 14. ./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&) @ 0x0000000019bf7c6d 15. ./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) @ 0x0000000019bf62c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000199666ff 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000019962b45 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001996a18e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000019971837 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019e929e9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000019994fc9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000019995bb5 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019997c22 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb188a8 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20286 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb201a2 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 29. __tsan_thread_start_func @ 0x000000000758af2f 30. ? @ 0x00007f00a651fac3 31. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:22.007122 [ 45844 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest2/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:22.007237 [ 45837 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:22.007385 [ 46004 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/source/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:22.007459 [ 46155 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest1/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:22.007425 [ 45861 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/data/replicas/data_r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:22.007496 [ 45830 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/data/replicas/data_r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:22.007648 [ 46230 ] {} test_15.replace_partition_dest2 (b6065388-ff6c-41db-b734-418c24868543): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest2/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:23.008157 [ 46157 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest2/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:23.008281 [ 46042 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/source/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:23.008309 [ 46047 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:23.008343 [ 46014 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/data/replicas/data_r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:23.008522 [ 46055 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest1/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:23.008681 [ 46048 ] {} test_15.replace_partition_dest2 (b6065388-ff6c-41db-b734-418c24868543): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest2/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:23.008677 [ 46037 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/data/replicas/data_r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.009124 [ 45955 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/source/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.009149 [ 46327 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest2/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.009195 [ 45934 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.009329 [ 46338 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/data/replicas/data_r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.009409 [ 46320 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest1/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.009623 [ 45920 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/data/replicas/data_r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.009664 [ 46171 ] {} test_15.replace_partition_dest2 (b6065388-ff6c-41db-b734-418c24868543): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest2/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193d06a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bfc2 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.715691 [ 46318 ] {} test_9.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.715676 [ 46334 ] {} test_9.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_0/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.715742 [ 46323 ] {} test_9.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_active. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2eb3 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:270: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d43372 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.716265 [ 46312 ] {} test_9.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.716404 [ 46277 ] {} test_3.i20203_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.716535 [ 46242 ] {} test_9.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.716795 [ 46257 ] {} test_9.alter_table_8 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.717079 [ 46271 ] {} test_slupgmk5.replicated_with_sampling (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.717513 [ 46314 ] {} test_9.alter_table_4 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas/r_9/is_lost. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000001add4152 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:672: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000001add3d14 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:268: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d430ec 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007f00a651fac3 18. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.717649 [ 46225 ] {} test_9.rep_data (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.717936 [ 46233 ] {} test_9.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.718360 [ 46324 ] {} test_9.alter_table_8 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x0000000019d4c522 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x0000000019d463d6 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40fa0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.718498 [ 46312 ] {} test_9.alter_table_7 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.718385 [ 46334 ] {} test_9.alter_table_5 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.718400 [ 46318 ] {} test_9.alter_table_0 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.718692 [ 46211 ] {} test_9.alter_table_9 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.718791 [ 46323 ] {} test_9.alter_table_9 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.718965 [ 46258 ] {} test_9.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.719437 [ 46193 ] {} test_9.alter_table_5 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.719781 [ 46314 ] {} test_9.alter_table_4 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.719861 [ 46250 ] {} test_9.alter_table_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.720159 [ 46278 ] {} test_9.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.720275 [ 46247 ] {} test_9.alter_table_0 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.720367 [ 46270 ] {} test_9.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.720564 [ 46189 ] {} test_3.replicated_table_for_alter2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.720977 [ 46183 ] {} test_9.alter_table_7 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.721032 [ 46202 ] {} test_9.alter_table_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.721250 [ 46259 ] {} test_1a87k00g.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.721959 [ 46243 ] {} test_3.replicated_table_for_alter1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.722255 [ 46168 ] {} test_9.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.12 19:24:24.724250 [ 46287 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/data/replicas/data_r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.724512 [ 46205 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest1/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.724912 [ 46292 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725195 [ 46190 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/data/replicas/data_r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725084 [ 46139 ] {} test_15.replace_partition_dest2 (b6065388-ff6c-41db-b734-418c24868543): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest2/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725582 [ 46179 ] {} test_15.replace_partition_dest1 (b6ec094a-46d0-4844-8109-c270bd3e3418): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725686 [ 46213 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725760 [ 46134 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725786 [ 46305 ] {} test_15.replace_partition_dest1_2 (0b6a719b-6b26-4cef-9f8c-89ff71e66448): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725683 [ 46158 ] {} test_15.replace_partition_source (4fc10e51-d37a-4dd5-b2d3-fe8d90bc6129): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/source/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725783 [ 46308 ] {} test_15.replace_partition_dest2 (b6065388-ff6c-41db-b734-418c24868543): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725846 [ 46229 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.725702 [ 46192 ] {} test_15.replace_partition_dest2_2 (d6d684cf-779d-4a87-a962-9a69ec9b2f78): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02271_replace_partition_many/test_15/dest2/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762aaa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000019331e20 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000193cb849 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf02 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b17b3 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 12. __tsan_thread_start_func @ 0x000000000758af2f 13. ? @ 0x00007f00a651fac3 14. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.726087 [ 46200 ] {} test_15.data_r2 (d6f4983c-b83e-4291-8e5b-954af243dc2b): 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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000001ae567d8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001adce195 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcdb75 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcebf4 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adceac1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x0000000019d89089 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000193cbd03 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001948bf42 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.726456 [ 46304 ] {} test_9.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_9/alter_table/replicas. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001adcec71 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce5d4 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001adce3d8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d4214f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 17. __tsan_thread_start_func @ 0x000000000758af2f 18. ? @ 0x00007f00a651fac3 19. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.727779 [ 46304 ] {} test_9.alter_table_1 (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001ae1322b 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000001ae526c0 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000001ae55a18 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add2bae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001add25b3 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001add2e53 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001adcf850 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x0000000019d41e14 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000019d40e7b 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x0000000019d3f939 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019d4e302 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169acaf2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b0e0e 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*) @ 0x00000000169b17b3 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb1541e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1d3bc 18. __tsan_thread_start_func @ 0x000000000758af2f 19. ? @ 0x00007f00a651fac3 20. ? @ 0x00007f00a65b1850 (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:24.850108 [ 45795 ] {} test_15.data_r1 (2ceea99f-1f23-4c7f-875c-5ba8f0edbbad): virtual void DB::StorageReplicatedMergeTree::shutdown(bool): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/data. (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) @ 0x000000001e594d03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09495 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001616f7e6 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001616e7ae 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:58: zkutil::ZooKeeper::sync(String const&) @ 0x000000001add638d 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::getZooKeeperIfTableShutDown() const @ 0x000000001935ed41 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4396: DB::StorageReplicatedMergeTree::waitForUniquePartsToBeFetchedByOtherReplicas(std::chrono::time_point>>) @ 0x00000000193de991 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5371: DB::StorageReplicatedMergeTree::shutdown(bool) @ 0x00000000193efba1 9. ./base/base/../base/wide_integer_impl.h:817: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x000000001712ea76 10. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:184: DB::DatabaseOnDisk::shutdown() @ 0x0000000017092f6b 11. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseCatalog::shutdownImpl() @ 0x000000001768d09f 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:867: DB::DatabaseCatalog::shutdown() @ 0x000000001769614c 13. ./build_docker/./src/Interpreters/Context.cpp:624: DB::ContextSharedPart::shutdown() @ 0x00000000175dcadd 14. ./build_docker/./src/Interpreters/Context.cpp:4783: DB::Context::shutdown() @ 0x00000000175ca462 15. ./build_docker/./programs/server/Server.cpp:0: BasicScopeGuard> const&)::$_2>::~BasicScopeGuard() @ 0x000000000fc66246 16. ./build_docker/./programs/server/Server.cpp:0: DB::Server::main(std::vector> const&) @ 0x000000000fc55dd6 17. ./build_docker/./base/poco/Util/src/Application.cpp:0: Poco::Util::Application::run() @ 0x000000001e6d9a9f 18. ./build_docker/./programs/server/Server.cpp:0: DB::Server::run() @ 0x000000000fc3b786 19. ./build_docker/./base/poco/Util/src/ServerApplication.cpp:0: Poco::Util::ServerApplication::run(int, char**) @ 0x000000001e6f82c1 20. ./build_docker/./programs/server/Server.cpp:0: mainEntryClickHouseServer(int, char**) @ 0x000000000fc385b6 21. ./build_docker/./programs/main.cpp:0: main @ 0x00000000076098e9 22. ? @ 0x00007f00a64b4d90 23. ? @ 0x00007f00a64b4e40 24. _start @ 0x000000000756402e (version 24.8.14.10057.altinitytest (altinity build)) 2025.06.12 19:24:26.917284 [ 46407 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled